From 07a6eed0fac2edce558eb263a8d84abd85c60e62 Mon Sep 17 00:00:00 2001 From: david-leifker <114954101+david-leifker@users.noreply.github.com> Date: Fri, 30 Aug 2024 14:54:49 -0500 Subject: [PATCH 01/34] fix(openlineage): fix jar conflict (#11278) --- metadata-integration/java/openlineage-converter/build.gradle | 4 ++++ 1 file changed, 4 insertions(+) diff --git a/metadata-integration/java/openlineage-converter/build.gradle b/metadata-integration/java/openlineage-converter/build.gradle index 6783d300a5fe44..2e04881ab5ccda 100644 --- a/metadata-integration/java/openlineage-converter/build.gradle +++ b/metadata-integration/java/openlineage-converter/build.gradle @@ -47,6 +47,10 @@ shadowJar { exclude('log4j2.*', 'log4j.*') } +jar { + archiveClassifier = 'lib' +} + //task sourcesJar(type: Jar) { // classifier 'sources' // from sourceSets.main.allJava From 3e5c18f5d25543141654c54d8122fdc42b9009b7 Mon Sep 17 00:00:00 2001 From: Mayuri Nehate <33225191+mayurinehate@users.noreply.github.com> Date: Sat, 31 Aug 2024 01:50:18 +0530 Subject: [PATCH 02/34] =?UTF-8?q?fix(ingest):=20limit=20number=20of=20upst?= =?UTF-8?q?reams=20generated=20by=20sql=20parsing=20aggre=E2=80=A6=20(#112?= =?UTF-8?q?67)?= MIME-Version: 1.0 Content-Type: text/plain; charset=UTF-8 Content-Transfer-Encoding: 8bit Co-authored-by: Harshal Sheth --- .../sql_parsing/sql_parsing_aggregator.py | 24 +++++++++++++++++++ 1 file changed, 24 insertions(+) diff --git a/metadata-ingestion/src/datahub/sql_parsing/sql_parsing_aggregator.py b/metadata-ingestion/src/datahub/sql_parsing/sql_parsing_aggregator.py index 764c2b42537bb4..ed4ea2cabee423 100644 --- a/metadata-ingestion/src/datahub/sql_parsing/sql_parsing_aggregator.py +++ b/metadata-ingestion/src/datahub/sql_parsing/sql_parsing_aggregator.py @@ -72,6 +72,8 @@ class QueryLogSetting(enum.Enum): _DEFAULT_QUERY_LOG_SETTING = QueryLogSetting[ os.getenv("DATAHUB_SQL_AGG_QUERY_LOG") or QueryLogSetting.DISABLED.name ] +MAX_UPSTREAM_TABLES_COUNT = 300 +MAX_FINEGRAINEDLINEAGE_COUNT = 2000 @dataclasses.dataclass @@ -229,6 +231,8 @@ class SqlAggregatorReport(Report): num_unique_query_fingerprints: Optional[int] = None num_urns_with_lineage: Optional[int] = None num_lineage_skipped_due_to_filters: int = 0 + num_table_lineage_trimmed_due_to_large_size: int = 0 + num_column_lineage_trimmed_due_to_large_size: int = 0 # Queries. num_queries_entities_generated: int = 0 @@ -1154,6 +1158,26 @@ def _gen_lineage_for_downstream( confidenceScore=queries_map[query_id].confidence_score, ) ) + + if len(upstream_aspect.upstreams) > MAX_UPSTREAM_TABLES_COUNT: + logger.warning( + f"Too many upstream tables for {downstream_urn}: {len(upstream_aspect.upstreams)}" + f"Keeping only {MAX_UPSTREAM_TABLES_COUNT} table level upstreams/" + ) + upstream_aspect.upstreams = upstream_aspect.upstreams[ + :MAX_UPSTREAM_TABLES_COUNT + ] + self.report.num_table_lineage_trimmed_due_to_large_size += 1 + if len(upstream_aspect.fineGrainedLineages) > MAX_FINEGRAINEDLINEAGE_COUNT: + logger.warning( + f"Too many upstream columns for {downstream_urn}: {len(upstream_aspect.fineGrainedLineages)}" + f"Keeping only {MAX_FINEGRAINEDLINEAGE_COUNT} column level upstreams/" + ) + upstream_aspect.fineGrainedLineages = upstream_aspect.fineGrainedLineages[ + :MAX_FINEGRAINEDLINEAGE_COUNT + ] + self.report.num_column_lineage_trimmed_due_to_large_size += 1 + upstream_aspect.fineGrainedLineages = ( upstream_aspect.fineGrainedLineages or None ) From c513e17dbb6f54ec1a3e835c94e479e64d4662a9 Mon Sep 17 00:00:00 2001 From: matthew-coudert-cko <113023884+matthew-coudert-cko@users.noreply.github.com> Date: Fri, 30 Aug 2024 21:25:18 +0100 Subject: [PATCH 03/34] feat(ingest/fivetran): support filtering on destination ids (#11277) --- .../src/datahub/ingestion/source/fivetran/config.py | 4 ++++ .../src/datahub/ingestion/source/fivetran/fivetran.py | 1 + .../ingestion/source/fivetran/fivetran_log_api.py | 4 ++++ .../tests/integration/fivetran/test_fivetran.py | 10 ++++++++++ 4 files changed, 19 insertions(+) diff --git a/metadata-ingestion/src/datahub/ingestion/source/fivetran/config.py b/metadata-ingestion/src/datahub/ingestion/source/fivetran/config.py index f8b1c6dd93d6d9..02eb096b240f52 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/fivetran/config.py +++ b/metadata-ingestion/src/datahub/ingestion/source/fivetran/config.py @@ -161,6 +161,10 @@ class FivetranSourceConfig(StatefulIngestionConfigBase, DatasetSourceConfigMixin default=AllowDenyPattern.allow_all(), description="Regex patterns for connectors to filter in ingestion.", ) + destination_patterns: AllowDenyPattern = Field( + default=AllowDenyPattern.allow_all(), + description="Regex patterns for destinations to filter in ingestion.", + ) include_column_lineage: bool = Field( default=True, description="Populates table->table column lineage.", diff --git a/metadata-ingestion/src/datahub/ingestion/source/fivetran/fivetran.py b/metadata-ingestion/src/datahub/ingestion/source/fivetran/fivetran.py index c899fe04d2c48e..b459b47deb153a 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/fivetran/fivetran.py +++ b/metadata-ingestion/src/datahub/ingestion/source/fivetran/fivetran.py @@ -283,6 +283,7 @@ def get_workunits_internal(self) -> Iterable[MetadataWorkUnit]: logger.info("Fivetran plugin execution is started") connectors = self.audit_log.get_allowed_connectors_list( self.config.connector_patterns, + self.config.destination_patterns, self.report, self.config.history_sync_lookback_period, ) diff --git a/metadata-ingestion/src/datahub/ingestion/source/fivetran/fivetran_log_api.py b/metadata-ingestion/src/datahub/ingestion/source/fivetran/fivetran_log_api.py index d8ce68e8345ec7..31c16139066e43 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/fivetran/fivetran_log_api.py +++ b/metadata-ingestion/src/datahub/ingestion/source/fivetran/fivetran_log_api.py @@ -251,6 +251,7 @@ def _fill_connectors_jobs( def get_allowed_connectors_list( self, connector_patterns: AllowDenyPattern, + destination_patterns: AllowDenyPattern, report: FivetranSourceReport, syncs_interval: int, ) -> List[Connector]: @@ -261,6 +262,9 @@ def get_allowed_connectors_list( if not connector_patterns.allowed(connector[Constant.CONNECTOR_NAME]): report.report_connectors_dropped(connector[Constant.CONNECTOR_NAME]) continue + if not destination_patterns.allowed(connector[Constant.DESTINATION_ID]): + report.report_connectors_dropped(connector[Constant.CONNECTOR_NAME]) + continue connectors.append( Connector( connector_id=connector[Constant.CONNECTOR_ID], diff --git a/metadata-ingestion/tests/integration/fivetran/test_fivetran.py b/metadata-ingestion/tests/integration/fivetran/test_fivetran.py index 5e0e20234cc992..0f5d098ee39c4a 100644 --- a/metadata-ingestion/tests/integration/fivetran/test_fivetran.py +++ b/metadata-ingestion/tests/integration/fivetran/test_fivetran.py @@ -205,6 +205,11 @@ def test_fivetran_with_snowflake_dest(pytestconfig, tmp_path): "postgres", ] }, + "destination_patterns": { + "allow": [ + "interval_unconstitutional", + ] + }, "sources_to_database": { "calendar_elected": "postgres_db", }, @@ -291,6 +296,11 @@ def test_fivetran_with_snowflake_dest_and_null_connector_user(pytestconfig, tmp_ "postgres", ] }, + "destination_patterns": { + "allow": [ + "interval_unconstitutional", + ] + }, "sources_to_database": { "calendar_elected": "postgres_db", }, From a7fc7f519ac4a6a4df38315c8eb3baf7c75ec25b Mon Sep 17 00:00:00 2001 From: Mayuri Nehate <33225191+mayurinehate@users.noreply.github.com> Date: Sat, 31 Aug 2024 06:46:45 +0530 Subject: [PATCH 04/34] feat(ingest/bq): integrate bigquery-queries into main source (#11247) --- .../ingestion/source/bigquery_v2/bigquery.py | 58 ++++- .../source/bigquery_v2/bigquery_config.py | 5 + .../source/bigquery_v2/bigquery_queries.py | 2 +- .../source/bigquery_v2/bigquery_report.py | 21 +- .../bigquery_v2/bigquery_test_connection.py | 5 +- .../ingestion/source/bigquery_v2/lineage.py | 180 ++++++------- .../source/bigquery_v2/queries_extractor.py | 70 +++--- .../source/snowflake/snowflake_v2.py | 2 +- .../sql_parsing/sql_parsing_aggregator.py | 21 +- .../bigquery_v2/bigquery_mcp_golden.json | 236 ++++++++++++++++++ .../integration/bigquery_v2/test_bigquery.py | 70 ++++-- .../bigquery_v2/test_bigquery_queries.py | 6 +- .../tests/unit/test_bigquery_lineage.py | 14 +- 13 files changed, 496 insertions(+), 194 deletions(-) diff --git a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery.py b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery.py index f37f5358f9e17d..cbd22b689e0d8b 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery.py +++ b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery.py @@ -39,6 +39,10 @@ ) from datahub.ingestion.source.bigquery_v2.lineage import BigqueryLineageExtractor from datahub.ingestion.source.bigquery_v2.profiler import BigqueryProfiler +from datahub.ingestion.source.bigquery_v2.queries_extractor import ( + BigQueryQueriesExtractor, + BigQueryQueriesExtractorConfig, +) from datahub.ingestion.source.bigquery_v2.usage import BigQueryUsageExtractor from datahub.ingestion.source.state.profiling_state_handler import ProfilingHandler from datahub.ingestion.source.state.redundant_run_skip_handler import ( @@ -51,6 +55,7 @@ from datahub.ingestion.source.state.stateful_ingestion_base import ( StatefulIngestionSourceBase, ) +from datahub.ingestion.source_report.ingestion_stage import QUERIES_EXTRACTION from datahub.sql_parsing.schema_resolver import SchemaResolver from datahub.utilities.registries.domain_registry import DomainRegistry @@ -139,6 +144,7 @@ def __init__(self, ctx: PipelineContext, config: BigQueryV2Config): self.lineage_extractor = BigqueryLineageExtractor( config, self.report, + schema_resolver=self.sql_parser_schema_resolver, identifiers=self.identifiers, redundant_run_skip_handler=redundant_lineage_run_skip_handler, ) @@ -196,7 +202,9 @@ def test_connection(config_dict: dict) -> TestConnectionReport: def _init_schema_resolver(self) -> SchemaResolver: schema_resolution_required = ( - self.config.lineage_parse_view_ddl or self.config.lineage_use_sql_parser + self.config.use_queries_v2 + or self.config.lineage_parse_view_ddl + or self.config.lineage_use_sql_parser ) schema_ingestion_enabled = ( self.config.include_schema_metadata @@ -244,22 +252,54 @@ def get_workunits_internal(self) -> Iterable[MetadataWorkUnit]: for project in projects: yield from self.bq_schema_extractor.get_project_workunits(project) - if self.config.include_usage_statistics: - yield from self.usage_extractor.get_usage_workunits( - [p.id for p in projects], self.bq_schema_extractor.table_refs - ) + if self.config.use_queries_v2: + self.report.set_ingestion_stage("*", "View and Snapshot Lineage") - if self.config.include_table_lineage: - yield from self.lineage_extractor.get_lineage_workunits( + yield from self.lineage_extractor.get_lineage_workunits_for_views_and_snapshots( [p.id for p in projects], - self.sql_parser_schema_resolver, self.bq_schema_extractor.view_refs_by_project, self.bq_schema_extractor.view_definitions, self.bq_schema_extractor.snapshot_refs_by_project, self.bq_schema_extractor.snapshots_by_ref, - self.bq_schema_extractor.table_refs, ) + self.report.set_ingestion_stage("*", QUERIES_EXTRACTION) + + queries_extractor = BigQueryQueriesExtractor( + connection=self.config.get_bigquery_client(), + schema_api=self.bq_schema_extractor.schema_api, + config=BigQueryQueriesExtractorConfig( + window=self.config, + user_email_pattern=self.config.usage.user_email_pattern, + include_lineage=self.config.include_table_lineage, + include_usage_statistics=self.config.include_usage_statistics, + include_operations=self.config.usage.include_operational_stats, + top_n_queries=self.config.usage.top_n_queries, + ), + structured_report=self.report, + filters=self.filters, + identifiers=self.identifiers, + schema_resolver=self.sql_parser_schema_resolver, + discovered_tables=self.bq_schema_extractor.table_refs, + ) + self.report.queries_extractor = queries_extractor.report + yield from queries_extractor.get_workunits_internal() + else: + if self.config.include_usage_statistics: + yield from self.usage_extractor.get_usage_workunits( + [p.id for p in projects], self.bq_schema_extractor.table_refs + ) + + if self.config.include_table_lineage: + yield from self.lineage_extractor.get_lineage_workunits( + [p.id for p in projects], + self.bq_schema_extractor.view_refs_by_project, + self.bq_schema_extractor.view_definitions, + self.bq_schema_extractor.snapshot_refs_by_project, + self.bq_schema_extractor.snapshots_by_ref, + self.bq_schema_extractor.table_refs, + ) + def get_report(self) -> BigQueryV2Report: return self.report diff --git a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_config.py b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_config.py index c5a8b2ab7fbe33..cfbefa5bff65ce 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_config.py +++ b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_config.py @@ -404,6 +404,11 @@ class BigQueryV2Config( "enabled.", ) + use_queries_v2: bool = Field( + default=False, + description="If enabled, uses the new queries extractor to extract queries from bigquery.", + ) + @property def have_table_data_read_permission(self) -> bool: return self.use_tables_list_query_v2 or self.is_profiling_enabled() diff --git a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_queries.py b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_queries.py index fffb5cfc8abfdf..ed27aae19ce963 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_queries.py +++ b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_queries.py @@ -15,6 +15,7 @@ BigQueryIdentifierConfig, ) from datahub.ingestion.source.bigquery_v2.bigquery_report import ( + BigQueryQueriesExtractorReport, BigQuerySchemaApiPerfReport, ) from datahub.ingestion.source.bigquery_v2.bigquery_schema import BigQuerySchemaApi @@ -25,7 +26,6 @@ from datahub.ingestion.source.bigquery_v2.queries_extractor import ( BigQueryQueriesExtractor, BigQueryQueriesExtractorConfig, - BigQueryQueriesExtractorReport, ) logger = logging.getLogger(__name__) diff --git a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_report.py b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_report.py index d68468fd56c9bc..b333bcf695a464 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_report.py +++ b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_report.py @@ -58,6 +58,18 @@ class BigQueryProcessingPerfReport(Report): usage_state_size: Optional[str] = None +@dataclass +class BigQueryQueriesExtractorReport(Report): + query_log_fetch_timer: PerfTimer = field(default_factory=PerfTimer) + audit_log_preprocessing_timer: PerfTimer = field(default_factory=PerfTimer) + audit_log_load_timer: PerfTimer = field(default_factory=PerfTimer) + sql_aggregator: Optional[SqlAggregatorReport] = None + num_queries_by_project: TopKDict[str, int] = field(default_factory=int_top_k_dict) + + num_total_queries: int = 0 + num_unique_queries: int = 0 + + @dataclass class BigQueryV2Report( ProfilingSqlReport, @@ -143,10 +155,8 @@ class BigQueryV2Report( snapshots_scanned: int = 0 - num_view_definitions_parsed: int = 0 - num_view_definitions_failed_parsing: int = 0 - num_view_definitions_failed_column_parsing: int = 0 - view_definitions_parsing_failures: LossyList[str] = field(default_factory=LossyList) + # view lineage + sql_aggregator: Optional[SqlAggregatorReport] = None read_reasons_stat: Counter[str] = field(default_factory=collections.Counter) operation_types_stat: Counter[str] = field(default_factory=collections.Counter) @@ -171,8 +181,7 @@ class BigQueryV2Report( usage_end_time: Optional[datetime] = None stateful_usage_ingestion_enabled: bool = False - # lineage/usage v2 - sql_aggregator: Optional[SqlAggregatorReport] = None + queries_extractor: Optional[BigQueryQueriesExtractorReport] = None def set_ingestion_stage(self, project_id: str, stage: str) -> None: self.report_ingestion_stage_start(f"{project_id}: {stage}") diff --git a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_test_connection.py b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_test_connection.py index d0f111f451c0e1..27beb7b0254c41 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_test_connection.py +++ b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_test_connection.py @@ -137,7 +137,10 @@ def lineage_capability_test( report: BigQueryV2Report, ) -> CapabilityReport: lineage_extractor = BigqueryLineageExtractor( - connection_conf, report, BigQueryIdentifierBuilder(connection_conf, report) + connection_conf, + report, + schema_resolver=SchemaResolver(platform="bigquery"), + identifiers=BigQueryIdentifierBuilder(connection_conf, report), ) for project_id in project_ids: try: diff --git a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/lineage.py b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/lineage.py index 16d472d4dedd2a..c9d0738bea7dca 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/lineage.py +++ b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/lineage.py @@ -24,6 +24,7 @@ from datahub.configuration.pattern_utils import is_schema_allowed from datahub.emitter import mce_builder from datahub.emitter.mcp import MetadataChangeProposalWrapper +from datahub.ingestion.api.source_helpers import auto_workunit from datahub.ingestion.api.workunit import MetadataWorkUnit from datahub.ingestion.source.bigquery_v2.bigquery_audit import ( AuditLogEntry, @@ -53,6 +54,7 @@ from datahub.ingestion.source.state.redundant_run_skip_handler import ( RedundantLineageRunSkipHandler, ) +from datahub.ingestion.source_report.ingestion_stage import LINEAGE_EXTRACTION from datahub.metadata.schema_classes import ( AuditStampClass, DatasetLineageTypeClass, @@ -63,6 +65,7 @@ UpstreamLineageClass, ) from datahub.sql_parsing.schema_resolver import SchemaResolver +from datahub.sql_parsing.sql_parsing_aggregator import SqlParsingAggregator from datahub.sql_parsing.sqlglot_lineage import SqlParsingResult, sqlglot_lineage from datahub.utilities import memory_footprint from datahub.utilities.file_backed_collections import FileBackedDict @@ -201,38 +204,20 @@ def make_lineage_edges_from_parsing_result( return list(table_edges.values()) -def make_lineage_edge_for_snapshot( - snapshot: BigqueryTableSnapshot, -) -> Optional[LineageEdge]: - if snapshot.base_table_identifier: - base_table_name = str( - BigQueryTableRef.from_bigquery_table(snapshot.base_table_identifier) - ) - return LineageEdge( - table=base_table_name, - column_mapping=frozenset( - LineageEdgeColumnMapping( - out_column=column.field_path, - in_columns=frozenset([column.field_path]), - ) - for column in snapshot.columns - ), - auditStamp=datetime.now(timezone.utc), - type=DatasetLineageTypeClass.TRANSFORMED, - ) - return None - - class BigqueryLineageExtractor: def __init__( self, config: BigQueryV2Config, report: BigQueryV2Report, + *, + schema_resolver: SchemaResolver, identifiers: BigQueryIdentifierBuilder, redundant_run_skip_handler: Optional[RedundantLineageRunSkipHandler] = None, ): self.config = config self.report = report + self.schema_resolver = schema_resolver + self.identifiers = identifiers self.audit_log_api = BigQueryAuditLogApi( report.audit_log_api_perf, @@ -246,6 +231,23 @@ def __init__( self.report.lineage_end_time, ) = self.get_time_window() + self.datasets_skip_audit_log_lineage: Set[str] = set() + + self.aggregator = SqlParsingAggregator( + platform=self.identifiers.platform, + platform_instance=self.identifiers.identifier_config.platform_instance, + env=self.identifiers.identifier_config.env, + schema_resolver=self.schema_resolver, + eager_graph_load=False, + generate_lineage=True, + generate_queries=True, + generate_usage_statistics=False, + generate_query_usage_statistics=False, + generate_operations=False, + format_queries=True, + ) + self.report.sql_aggregator = self.aggregator.report + def get_time_window(self) -> Tuple[datetime, datetime]: if self.redundant_run_skip_handler: return self.redundant_run_skip_handler.suggest_run_time_window( @@ -271,10 +273,46 @@ def _should_ingest_lineage(self) -> bool: return True + def get_lineage_workunits_for_views_and_snapshots( + self, + projects: List[str], + view_refs_by_project: Dict[str, Set[str]], + view_definitions: FileBackedDict[str], + snapshot_refs_by_project: Dict[str, Set[str]], + snapshots_by_ref: FileBackedDict[BigqueryTableSnapshot], + ) -> Iterable[MetadataWorkUnit]: + for project in projects: + if self.config.lineage_parse_view_ddl: + for view in view_refs_by_project[project]: + self.datasets_skip_audit_log_lineage.add(view) + self.aggregator.add_view_definition( + view_urn=self.identifiers.gen_dataset_urn_from_raw_ref( + BigQueryTableRef.from_string_name(view) + ), + view_definition=view_definitions[view], + default_db=project, + ) + + for snapshot_ref in snapshot_refs_by_project[project]: + snapshot = snapshots_by_ref[snapshot_ref] + if not snapshot.base_table_identifier: + continue + self.datasets_skip_audit_log_lineage.add(snapshot_ref) + snapshot_urn = self.identifiers.gen_dataset_urn_from_raw_ref( + BigQueryTableRef.from_string_name(snapshot_ref) + ) + base_table_urn = self.identifiers.gen_dataset_urn_from_raw_ref( + BigQueryTableRef(snapshot.base_table_identifier) + ) + self.aggregator.add_known_lineage_mapping( + upstream_urn=base_table_urn, downstream_urn=snapshot_urn + ) + + yield from auto_workunit(self.aggregator.gen_metadata()) + def get_lineage_workunits( self, projects: List[str], - sql_parser_schema_resolver: SchemaResolver, view_refs_by_project: Dict[str, Set[str]], view_definitions: FileBackedDict[str], snapshot_refs_by_project: Dict[str, Set[str]], @@ -283,39 +321,22 @@ def get_lineage_workunits( ) -> Iterable[MetadataWorkUnit]: if not self._should_ingest_lineage(): return - datasets_skip_audit_log_lineage: Set[str] = set() - dataset_lineage: Dict[str, Set[LineageEdge]] = {} - for project in projects: - self.populate_snapshot_lineage( - dataset_lineage, - snapshot_refs_by_project[project], - snapshots_by_ref, - ) - - if self.config.lineage_parse_view_ddl: - self.populate_view_lineage_with_sql_parsing( - dataset_lineage, - view_refs_by_project[project], - view_definitions, - sql_parser_schema_resolver, - project, - ) - datasets_skip_audit_log_lineage.update(dataset_lineage.keys()) - for lineage_key in dataset_lineage.keys(): - yield from self.gen_lineage_workunits_for_table( - dataset_lineage, BigQueryTableRef.from_string_name(lineage_key) - ) + yield from self.get_lineage_workunits_for_views_and_snapshots( + projects, + view_refs_by_project, + view_definitions, + snapshot_refs_by_project, + snapshots_by_ref, + ) if self.config.use_exported_bigquery_audit_metadata: projects = ["*"] # project_id not used when using exported metadata for project in projects: - self.report.set_ingestion_stage(project, "Lineage Extraction") + self.report.set_ingestion_stage(project, LINEAGE_EXTRACTION) yield from self.generate_lineage( project, - sql_parser_schema_resolver, - datasets_skip_audit_log_lineage, table_refs, ) @@ -328,8 +349,6 @@ def get_lineage_workunits( def generate_lineage( self, project_id: str, - sql_parser_schema_resolver: SchemaResolver, - datasets_skip_audit_log_lineage: Set[str], table_refs: Set[str], ) -> Iterable[MetadataWorkUnit]: logger.info(f"Generate lineage for {project_id}") @@ -339,9 +358,7 @@ def generate_lineage( lineage = self.lineage_via_catalog_lineage_api(project_id) else: events = self._get_parsed_audit_log_events(project_id) - lineage = self._create_lineage_map( - events, sql_parser_schema_resolver - ) + lineage = self._create_lineage_map(events) except Exception as e: self.report.lineage_failed_extraction.append(project_id) self.report.warning( @@ -367,7 +384,7 @@ def generate_lineage( # as they may contain indirectly referenced tables. if ( lineage_key not in table_refs - or lineage_key in datasets_skip_audit_log_lineage + or lineage_key in self.datasets_skip_audit_log_lineage ): continue @@ -375,58 +392,6 @@ def generate_lineage( lineage, BigQueryTableRef.from_string_name(lineage_key) ) - def populate_view_lineage_with_sql_parsing( - self, - view_lineage: Dict[str, Set[LineageEdge]], - view_refs: Set[str], - view_definitions: FileBackedDict[str], - sql_parser_schema_resolver: SchemaResolver, - default_project: str, - ) -> None: - for view in view_refs: - view_definition = view_definitions[view] - raw_view_lineage = sqlglot_lineage( - view_definition, - schema_resolver=sql_parser_schema_resolver, - default_db=default_project, - ) - if raw_view_lineage.debug_info.table_error: - logger.debug( - f"Failed to parse lineage for view {view}: {raw_view_lineage.debug_info.table_error}" - ) - self.report.num_view_definitions_failed_parsing += 1 - self.report.view_definitions_parsing_failures.append( - f"Table-level sql parsing error for view {view}: {raw_view_lineage.debug_info.table_error}" - ) - continue - elif raw_view_lineage.debug_info.column_error: - self.report.num_view_definitions_failed_column_parsing += 1 - self.report.view_definitions_parsing_failures.append( - f"Column-level sql parsing error for view {view}: {raw_view_lineage.debug_info.column_error}" - ) - else: - self.report.num_view_definitions_parsed += 1 - - ts = datetime.now(timezone.utc) - view_lineage[view] = set( - make_lineage_edges_from_parsing_result( - raw_view_lineage, - audit_stamp=ts, - lineage_type=DatasetLineageTypeClass.VIEW, - ) - ) - - def populate_snapshot_lineage( - self, - snapshot_lineage: Dict[str, Set[LineageEdge]], - snapshot_refs: Set[str], - snapshots_by_ref: FileBackedDict[BigqueryTableSnapshot], - ) -> None: - for snapshot in snapshot_refs: - lineage_edge = make_lineage_edge_for_snapshot(snapshots_by_ref[snapshot]) - if lineage_edge: - snapshot_lineage[snapshot] = {lineage_edge} - def gen_lineage_workunits_for_table( self, lineage: Dict[str, Set[LineageEdge]], table_ref: BigQueryTableRef ) -> Iterable[MetadataWorkUnit]: @@ -687,7 +652,6 @@ def _parse_exported_bigquery_audit_metadata( def _create_lineage_map( self, entries: Iterable[QueryEvent], - sql_parser_schema_resolver: SchemaResolver, ) -> Dict[str, Set[LineageEdge]]: logger.info("Entering create lineage map function") lineage_map: Dict[str, Set[LineageEdge]] = collections.defaultdict(set) @@ -751,7 +715,7 @@ def _create_lineage_map( query = e.query raw_lineage = sqlglot_lineage( query, - schema_resolver=sql_parser_schema_resolver, + schema_resolver=self.schema_resolver, default_db=e.project_id, ) logger.debug( diff --git a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/queries_extractor.py b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/queries_extractor.py index 8457f4e37b3d26..8e1d27847f2b68 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/queries_extractor.py +++ b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/queries_extractor.py @@ -2,25 +2,29 @@ import logging import pathlib import tempfile -from dataclasses import dataclass, field from datetime import datetime, timezone -from typing import Dict, Iterable, List, Optional, TypedDict +from typing import Collection, Dict, Iterable, List, Optional, TypedDict from google.cloud.bigquery import Client -from pydantic import Field +from pydantic import Field, PositiveInt from datahub.configuration.common import AllowDenyPattern from datahub.configuration.time_window_config import ( BaseTimeWindowConfig, get_time_bucket, ) -from datahub.ingestion.api.report import Report from datahub.ingestion.api.source import SourceReport from datahub.ingestion.api.source_helpers import auto_workunit from datahub.ingestion.api.workunit import MetadataWorkUnit from datahub.ingestion.graph.client import DataHubGraph -from datahub.ingestion.source.bigquery_v2.bigquery_audit import BigqueryTableIdentifier +from datahub.ingestion.source.bigquery_v2.bigquery_audit import ( + BigqueryTableIdentifier, + BigQueryTableRef, +) from datahub.ingestion.source.bigquery_v2.bigquery_config import BigQueryBaseConfig +from datahub.ingestion.source.bigquery_v2.bigquery_report import ( + BigQueryQueriesExtractorReport, +) from datahub.ingestion.source.bigquery_v2.bigquery_schema import ( BigqueryProject, BigQuerySchemaApi, @@ -35,7 +39,6 @@ from datahub.sql_parsing.schema_resolver import SchemaResolver from datahub.sql_parsing.sql_parsing_aggregator import ( ObservedQuery, - SqlAggregatorReport, SqlParsingAggregator, ) from datahub.sql_parsing.sqlglot_utils import get_query_fingerprint @@ -44,8 +47,6 @@ FileBackedDict, FileBackedList, ) -from datahub.utilities.perf_timer import PerfTimer -from datahub.utilities.stats_collections import TopKDict, int_top_k_dict from datahub.utilities.time import datetime_to_ts_millis logger = logging.getLogger(__name__) @@ -95,6 +96,10 @@ class BigQueryQueriesExtractorConfig(BigQueryBaseConfig): description="regex patterns for user emails to filter in usage.", ) + top_n_queries: PositiveInt = Field( + default=10, description="Number of top queries to save to each table." + ) + include_lineage: bool = True include_queries: bool = True include_usage_statistics: bool = True @@ -108,18 +113,6 @@ class BigQueryQueriesExtractorConfig(BigQueryBaseConfig): ) -@dataclass -class BigQueryQueriesExtractorReport(Report): - query_log_fetch_timer: PerfTimer = field(default_factory=PerfTimer) - audit_log_preprocessing_timer: PerfTimer = field(default_factory=PerfTimer) - audit_log_load_timer: PerfTimer = field(default_factory=PerfTimer) - sql_aggregator: Optional[SqlAggregatorReport] = None - num_queries_by_project: TopKDict[str, int] = field(default_factory=int_top_k_dict) - - num_total_queries: int = 0 - num_unique_queries: int = 0 - - class BigQueryQueriesExtractor: """ Extracts query audit log and generates usage/lineage/operation workunits. @@ -128,6 +121,7 @@ class BigQueryQueriesExtractor: 1. For every lineage/operation workunit, corresponding query id is also present 2. Operation aspect for a particular query is emitted at max once(last occurence) for a day 3. "DROP" operation accounts for usage here + 4. userEmail is not populated in datasetUsageStatistics aspect, only user urn """ @@ -141,7 +135,7 @@ def __init__( identifiers: BigQueryIdentifierBuilder, graph: Optional[DataHubGraph] = None, schema_resolver: Optional[SchemaResolver] = None, - discovered_tables: Optional[List[str]] = None, + discovered_tables: Optional[Collection[str]] = None, ): self.connection = connection @@ -150,8 +144,7 @@ def __init__( self.identifiers = identifiers self.schema_api = schema_api self.report = BigQueryQueriesExtractorReport() - # self.filters = filters - self.discovered_tables = discovered_tables + self.discovered_tables = set(discovered_tables) if discovered_tables else None self.structured_report = structured_report @@ -171,6 +164,7 @@ def __init__( start_time=self.config.window.start_time, end_time=self.config.window.end_time, user_email_pattern=self.config.user_email_pattern, + top_n_queries=self.config.top_n_queries, ), generate_operations=self.config.include_operations, is_temp_table=self.is_temp_table, @@ -192,19 +186,35 @@ def local_temp_path(self) -> pathlib.Path: def is_temp_table(self, name: str) -> bool: try: - return BigqueryTableIdentifier.from_string_name(name).dataset.startswith( - self.config.temp_table_dataset_prefix - ) + table = BigqueryTableIdentifier.from_string_name(name) + + if table.dataset.startswith(self.config.temp_table_dataset_prefix): + return True + + # This is also a temp table if + # 1. this name would be allowed by the dataset patterns, and + # 2. we have a list of discovered tables, and + # 3. it's not in the discovered tables list + if ( + self.filters.is_allowed(table) + and self.discovered_tables + and str(BigQueryTableRef(table)) not in self.discovered_tables + ): + return True + except Exception: logger.warning(f"Error parsing table name {name} ") - return False + return False def is_allowed_table(self, name: str) -> bool: try: - table_id = BigqueryTableIdentifier.from_string_name(name) - if self.discovered_tables and str(table_id) not in self.discovered_tables: + table = BigqueryTableIdentifier.from_string_name(name) + if ( + self.discovered_tables + and str(BigQueryTableRef(table)) not in self.discovered_tables + ): return False - return self.filters.is_allowed(table_id) + return self.filters.is_allowed(table) except Exception: logger.warning(f"Error parsing table name {name} ") return False diff --git a/metadata-ingestion/src/datahub/ingestion/source/snowflake/snowflake_v2.py b/metadata-ingestion/src/datahub/ingestion/source/snowflake/snowflake_v2.py index 0c861b1334d9fa..4da232518cde2d 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/snowflake/snowflake_v2.py +++ b/metadata-ingestion/src/datahub/ingestion/source/snowflake/snowflake_v2.py @@ -166,7 +166,7 @@ def __init__(self, ctx: PipelineContext, config: SnowflakeV2Config): # If we're ingestion schema metadata for tables/views, then we will populate # schemas into the resolver as we go. We only need to do a bulk fetch # if we're not ingesting schema metadata as part of ingestion. - ( + not ( self.config.include_technical_schema and self.config.include_tables and self.config.include_views diff --git a/metadata-ingestion/src/datahub/sql_parsing/sql_parsing_aggregator.py b/metadata-ingestion/src/datahub/sql_parsing/sql_parsing_aggregator.py index ed4ea2cabee423..29204c58fa4b9a 100644 --- a/metadata-ingestion/src/datahub/sql_parsing/sql_parsing_aggregator.py +++ b/metadata-ingestion/src/datahub/sql_parsing/sql_parsing_aggregator.py @@ -37,6 +37,7 @@ from datahub.sql_parsing.sqlglot_lineage import ( ColumnLineageInfo, ColumnRef, + DownstreamColumnRef, SqlParsingResult, infer_output_schema, sqlglot_lineage, @@ -574,9 +575,6 @@ def add_known_lineage_mapping( Because this method takes in urns, it does not require that the urns are part of the platform that the aggregator is configured for. - TODO: In the future, this method will also generate CLL if we have - schemas for either the upstream or downstream. - The known lineage mapping does not contribute to usage statistics or operations. Args: @@ -589,6 +587,21 @@ def add_known_lineage_mapping( # We generate a fake "query" object to hold the lineage. query_id = self._known_lineage_query_id() + # Generate CLL if schema of downstream is known + column_lineage: List[ColumnLineageInfo] = [] + if self._schema_resolver.has_urn(downstream_urn): + schema = self._schema_resolver._resolve_schema_info(downstream_urn) + if schema: + column_lineage = [ + ColumnLineageInfo( + downstream=DownstreamColumnRef( + table=downstream_urn, column=field_path + ), + upstreams=[ColumnRef(table=upstream_urn, column=field_path)], + ) + for field_path in schema + ] + # Register the query. self._add_to_query_map( QueryMetadata( @@ -600,7 +613,7 @@ def add_known_lineage_mapping( latest_timestamp=None, actor=None, upstreams=[upstream_urn], - column_lineage=[], + column_lineage=column_lineage, column_usage={}, confidence_score=1.0, ) diff --git a/metadata-ingestion/tests/integration/bigquery_v2/bigquery_mcp_golden.json b/metadata-ingestion/tests/integration/bigquery_v2/bigquery_mcp_golden.json index e7b2a7c4a9f4bb..bcbdd02506f734 100644 --- a/metadata-ingestion/tests/integration/bigquery_v2/bigquery_mcp_golden.json +++ b/metadata-ingestion/tests/integration/bigquery_v2/bigquery_mcp_golden.json @@ -401,6 +401,22 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.snapshot-table-1,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "glossaryTerm", "entityUrn": "urn:li:glossaryTerm:Age", @@ -417,6 +433,97 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.snapshot-table-1,PROD)", + "changeType": "UPSERT", + "aspectName": "schemaMetadata", + "aspect": { + "json": { + "schemaName": "project-id-1.bigquery-dataset-1.snapshot-table-1", + "platform": "urn:li:dataPlatform:bigquery", + "version": 0, + "created": { + "time": 0, + "actor": "urn:li:corpuser:unknown" + }, + "lastModified": { + "time": 0, + "actor": "urn:li:corpuser:unknown" + }, + "hash": "", + "platformSchema": { + "com.linkedin.schema.MySqlDDL": { + "tableSchema": "" + } + }, + "fields": [ + { + "fieldPath": "age", + "nullable": false, + "description": "comment", + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "nativeDataType": "INT", + "recursive": false, + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Test Policy Tag" + } + ] + }, + "isPartOfKey": false + }, + { + "fieldPath": "email", + "nullable": false, + "description": "comment", + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "nativeDataType": "STRING", + "recursive": false, + "globalTags": { + "tags": [] + }, + "isPartOfKey": false + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.snapshot-table-1,PROD)", + "changeType": "UPSERT", + "aspectName": "datasetProperties", + "aspect": { + "json": { + "customProperties": {}, + "externalUrl": "https://console.cloud.google.com/bigquery?project=project-id-1&ws=!1m5!1m4!4m3!1sproject-id-1!2sbigquery-dataset-1!3ssnapshot-table-1", + "name": "snapshot-table-1", + "qualifiedName": "project-id-1.bigquery-dataset-1.snapshot-table-1", + "description": "", + "tags": [] + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "glossaryTerm", "entityUrn": "urn:li:glossaryTerm:Email_Address", @@ -433,6 +540,57 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.snapshot-table-1,PROD)", + "changeType": "UPSERT", + "aspectName": "subTypes", + "aspect": { + "json": { + "typeNames": [ + "Bigquery Table Snapshot" + ] + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.snapshot-table-1,PROD)", + "changeType": "UPSERT", + "aspectName": "container", + "aspect": { + "json": { + "container": "urn:li:container:8df46c5e3ded05a3122b0015822c0ef0" + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.snapshot-table-1,PROD)", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery", + "instance": "urn:li:dataPlatformInstance:(urn:li:dataPlatform:bigquery,project-id-1)" + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "tag", "entityUrn": "urn:li:tag:Test Policy Tag", @@ -448,5 +606,83 @@ "runId": "bigquery-2022_02_03-07_00_00", "lastRunId": "no-run-id-provided" } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.snapshot-table-1,PROD)", + "changeType": "UPSERT", + "aspectName": "browsePathsV2", + "aspect": { + "json": { + "path": [ + { + "id": "urn:li:container:068bd9323110994a40019fcf6cfc60d3", + "urn": "urn:li:container:068bd9323110994a40019fcf6cfc60d3" + }, + { + "id": "urn:li:container:8df46c5e3ded05a3122b0015822c0ef0", + "urn": "urn:li:container:8df46c5e3ded05a3122b0015822c0ef0" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.snapshot-table-1,PROD)", + "changeType": "UPSERT", + "aspectName": "upstreamLineage", + "aspect": { + "json": { + "upstreams": [ + { + "auditStamp": { + "time": 1643871600000, + "actor": "urn:li:corpuser:_ingestion" + }, + "created": { + "time": 0, + "actor": "urn:li:corpuser:_ingestion" + }, + "dataset": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.table-1,PROD)", + "type": "COPY" + } + ], + "fineGrainedLineages": [ + { + "upstreamType": "FIELD_SET", + "upstreams": [ + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.table-1,PROD),age)" + ], + "downstreamType": "FIELD", + "downstreams": [ + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.snapshot-table-1,PROD),age)" + ], + "confidenceScore": 1.0 + }, + { + "upstreamType": "FIELD_SET", + "upstreams": [ + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.table-1,PROD),email)" + ], + "downstreamType": "FIELD", + "downstreams": [ + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.snapshot-table-1,PROD),email)" + ], + "confidenceScore": 1.0 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } } ] \ No newline at end of file diff --git a/metadata-ingestion/tests/integration/bigquery_v2/test_bigquery.py b/metadata-ingestion/tests/integration/bigquery_v2/test_bigquery.py index dff7f18db6135c..36199ee0e26000 100644 --- a/metadata-ingestion/tests/integration/bigquery_v2/test_bigquery.py +++ b/metadata-ingestion/tests/integration/bigquery_v2/test_bigquery.py @@ -11,6 +11,7 @@ DynamicTypedClassifierConfig, ) from datahub.ingestion.glossary.datahub_classifier import DataHubClassifierConfig +from datahub.ingestion.source.bigquery_v2.bigquery_audit import BigqueryTableIdentifier from datahub.ingestion.source.bigquery_v2.bigquery_data_reader import BigQueryDataReader from datahub.ingestion.source.bigquery_v2.bigquery_schema import ( BigqueryColumn, @@ -18,6 +19,7 @@ BigqueryProject, BigQuerySchemaApi, BigqueryTable, + BigqueryTableSnapshot, ) from datahub.ingestion.source.bigquery_v2.bigquery_schema_gen import ( BigQuerySchemaGenerator, @@ -47,7 +49,7 @@ def recipe(mcp_output_path: str, override: dict = {}) -> dict: "config": { "project_ids": ["project-id-1"], "include_usage_statistics": False, - "include_table_lineage": False, + "include_table_lineage": True, "include_data_platform_instance": True, "classification": ClassificationConfig( enabled=True, @@ -68,6 +70,7 @@ def recipe(mcp_output_path: str, override: dict = {}) -> dict: @freeze_time(FROZEN_TIME) +@patch.object(BigQuerySchemaApi, "get_snapshots_for_dataset") @patch.object(BigQuerySchemaApi, "get_tables_for_dataset") @patch.object(BigQuerySchemaGenerator, "get_core_table_details") @patch.object(BigQuerySchemaApi, "get_datasets_for_project_id") @@ -85,6 +88,7 @@ def test_bigquery_v2_ingest( get_datasets_for_project_id, get_core_table_details, get_tables_for_dataset, + get_snapshots_for_dataset, pytestconfig, tmp_path, ): @@ -100,31 +104,35 @@ def test_bigquery_v2_ingest( {"tableReference": {"projectId": "", "datasetId": "", "tableId": ""}} ) table_name = "table-1" + snapshot_table_name = "snapshot-table-1" get_core_table_details.return_value = {table_name: table_list_item} + columns = [ + BigqueryColumn( + name="age", + ordinal_position=1, + is_nullable=False, + field_path="col_1", + data_type="INT", + comment="comment", + is_partition_column=False, + cluster_column_position=None, + policy_tags=["Test Policy Tag"], + ), + BigqueryColumn( + name="email", + ordinal_position=1, + is_nullable=False, + field_path="col_2", + data_type="STRING", + comment="comment", + is_partition_column=False, + cluster_column_position=None, + ), + ] + get_columns_for_dataset.return_value = { - table_name: [ - BigqueryColumn( - name="age", - ordinal_position=1, - is_nullable=False, - field_path="col_1", - data_type="INT", - comment="comment", - is_partition_column=False, - cluster_column_position=None, - policy_tags=["Test Policy Tag"], - ), - BigqueryColumn( - name="email", - ordinal_position=1, - is_nullable=False, - field_path="col_2", - data_type="STRING", - comment="comment", - is_partition_column=False, - cluster_column_position=None, - ), - ] + table_name: columns, + snapshot_table_name: columns, } get_sample_data_for_table.return_value = { "age": [random.randint(1, 80) for i in range(20)], @@ -140,6 +148,20 @@ def test_bigquery_v2_ingest( rows_count=None, ) get_tables_for_dataset.return_value = iter([bigquery_table]) + snapshot_table = BigqueryTableSnapshot( + name=snapshot_table_name, + comment=None, + created=None, + last_altered=None, + size_in_bytes=None, + rows_count=None, + base_table_identifier=BigqueryTableIdentifier( + project_id="project-id-1", + dataset="bigquery-dataset-1", + table="table-1", + ), + ) + get_snapshots_for_dataset.return_value = iter([snapshot_table]) pipeline_config_dict: Dict[str, Any] = recipe(mcp_output_path=mcp_output_path) diff --git a/metadata-ingestion/tests/integration/bigquery_v2/test_bigquery_queries.py b/metadata-ingestion/tests/integration/bigquery_v2/test_bigquery_queries.py index fb51aac9fa246d..d9effd33f5d278 100644 --- a/metadata-ingestion/tests/integration/bigquery_v2/test_bigquery_queries.py +++ b/metadata-ingestion/tests/integration/bigquery_v2/test_bigquery_queries.py @@ -6,7 +6,6 @@ import pytest from freezegun import freeze_time -from datahub.ingestion.source.usage.usage_common import BaseUsageConfig from datahub.sql_parsing.sql_parsing_aggregator import ObservedQuery from datahub.utilities.file_backed_collections import ConnectionWrapper, FileBackedList from tests.test_helpers import mce_helpers @@ -58,15 +57,12 @@ def test_queries_ingestion(project_client, client, pytestconfig, monkeypatch, tm "config": { "project_ids": ["gcp-staging", "gcp-staging-2"], "local_temp_path": tmp_path, + "top_n_queries": 20, }, }, "sink": {"type": "file", "config": {"filename": mcp_output_path}}, } - # This is hacky to pick all queries instead of any 10. - # Should be easy to remove once top_n_queries is supported in queries config - monkeypatch.setattr(BaseUsageConfig.__fields__["top_n_queries"], "default", 20) - pipeline = run_and_get_pipeline(pipeline_config_dict) pipeline.pretty_print_summary() diff --git a/metadata-ingestion/tests/unit/test_bigquery_lineage.py b/metadata-ingestion/tests/unit/test_bigquery_lineage.py index 6bd5cc4d3226e2..7456f2fd1d91c2 100644 --- a/metadata-ingestion/tests/unit/test_bigquery_lineage.py +++ b/metadata-ingestion/tests/unit/test_bigquery_lineage.py @@ -83,7 +83,10 @@ def test_lineage_with_timestamps(lineage_entries: List[QueryEvent]) -> None: config = BigQueryV2Config() report = BigQueryV2Report() extractor: BigqueryLineageExtractor = BigqueryLineageExtractor( - config, report, BigQueryIdentifierBuilder(config, report) + config, + report, + schema_resolver=SchemaResolver(platform="bigquery"), + identifiers=BigQueryIdentifierBuilder(config, report), ) bq_table = BigQueryTableRef.from_string_name( @@ -91,8 +94,7 @@ def test_lineage_with_timestamps(lineage_entries: List[QueryEvent]) -> None: ) lineage_map: Dict[str, Set[LineageEdge]] = extractor._create_lineage_map( - iter(lineage_entries), - sql_parser_schema_resolver=SchemaResolver(platform="bigquery"), + iter(lineage_entries) ) upstream_lineage = extractor.get_lineage_for_table( @@ -108,7 +110,10 @@ def test_column_level_lineage(lineage_entries: List[QueryEvent]) -> None: config = BigQueryV2Config(extract_column_lineage=True, incremental_lineage=False) report = BigQueryV2Report() extractor: BigqueryLineageExtractor = BigqueryLineageExtractor( - config, report, BigQueryIdentifierBuilder(config, report) + config, + report, + schema_resolver=SchemaResolver(platform="bigquery"), + identifiers=BigQueryIdentifierBuilder(config, report), ) bq_table = BigQueryTableRef.from_string_name( @@ -117,7 +122,6 @@ def test_column_level_lineage(lineage_entries: List[QueryEvent]) -> None: lineage_map: Dict[str, Set[LineageEdge]] = extractor._create_lineage_map( lineage_entries[:1], - sql_parser_schema_resolver=SchemaResolver(platform="bigquery"), ) upstream_lineage = extractor.get_lineage_for_table( From bd5925ac1bfa754b84451789167b466ee0ecb665 Mon Sep 17 00:00:00 2001 From: Aseem Bansal Date: Mon, 2 Sep 2024 15:30:55 +0530 Subject: [PATCH 05/34] doc(acryl cloud): release notes for 0.3.5.x (#11259) Co-authored-by: david-leifker <114954101+david-leifker@users.noreply.github.com> Co-authored-by: Jay <159848059+jayacryl@users.noreply.github.com> --- docs-website/sidebars.js | 1 + docs/managed-datahub/release-notes/v_0_3_5.md | 33 +++++++++++++++++++ 2 files changed, 34 insertions(+) create mode 100644 docs/managed-datahub/release-notes/v_0_3_5.md diff --git a/docs-website/sidebars.js b/docs-website/sidebars.js index 20bed6099cdae3..0382f821a31ca3 100644 --- a/docs-website/sidebars.js +++ b/docs-website/sidebars.js @@ -307,6 +307,7 @@ module.exports = { }, { "DataHub Cloud Release History": [ + "docs/managed-datahub/release-notes/v_0_3_5", "docs/managed-datahub/release-notes/v_0_3_4", "docs/managed-datahub/release-notes/v_0_3_3", "docs/managed-datahub/release-notes/v_0_3_2", diff --git a/docs/managed-datahub/release-notes/v_0_3_5.md b/docs/managed-datahub/release-notes/v_0_3_5.md new file mode 100644 index 00000000000000..468f2bd59a918b --- /dev/null +++ b/docs/managed-datahub/release-notes/v_0_3_5.md @@ -0,0 +1,33 @@ +# v0.3.5 +--- + +Release Availability Date +--- +02-Sep-2024 + +Recommended CLI/SDK +--- +- `v0.14.0.2` with release notes at https://github.com/acryldata/datahub/releases/tag/v0.14.0.2 + +If you are using an older CLI/SDK version, then please upgrade it. This applies for all CLI/SDK usages, if you are using it through your terminal, GitHub Actions, Airflow, in Python SDK somewhere, Java SDK, etc. This is a strong recommendation to upgrade, as we keep on pushing fixes in the CLI, and it helps us support you better. + +## Release Changelog +--- + +- All changes in https://github.com/datahub-project/datahub/releases/tag/v0.14.0.2 + - Note Breaking Changes: https://datahubproject.io/docs/how/updating-datahub/#0140 + +- Product changes + - Misc fixes and improvements for the Snowflake Tag Propagation Automation (Beta) + - Misc fixes and improvements for the Glossary Term Tag Propagation Automation (Beta) + - Misc fixes and improvements for the Column Docs Propagation Automation (Beta) + - Minor UX improvements on the groups profile page + - Add 'Explore All' button to search dropdown permanently + - Add toggle to filter out transformations in lineage viz + - Misc fixes and minor improvements around the subscriptions and slack integrations experience + - The new slack ingestion source enables one-click subscriptions for your users by automatically hydrating users' memberID. New users who sign up will also automatically have their memberIDs hydrated. + - Please reach out to the Acryl team to get assistance in setting this up. + - Installing or Re-installing the slackbot will now enable the `/datahub` command and ensure your `botToken` is compatible with the new slack ingestion source. You can reach out to the Acryl team for assistance with re-installation. + +- Ingestion changes + - New configuration for dbt lineage, "merges" sources with their sibling in viz: set `prefer_sql_parser_lineage` and `skip_sources_in_lineage` in ingestion; set flag `HIDE_DBT_SOURCE_IN_LINEAGE=true` in gms From 1f3688a1ed83a5a947f1ed304b21191d7822a33d Mon Sep 17 00:00:00 2001 From: Mayuri Nehate <33225191+mayurinehate@users.noreply.github.com> Date: Mon, 2 Sep 2024 19:09:45 +0530 Subject: [PATCH 06/34] feat(ingest/databricks): include metadata for browse only tables (#10766) Co-authored-by: Harshal Sheth --- metadata-ingestion/setup.py | 1 + .../source/unity/hive_metastore_proxy.py | 4 ++-- .../src/datahub/ingestion/source/unity/proxy.py | 16 +++++++++++----- .../unity/test_unity_catalog_ingest.py | 5 ++++- 4 files changed, 18 insertions(+), 8 deletions(-) diff --git a/metadata-ingestion/setup.py b/metadata-ingestion/setup.py index 22ff8025aa0a06..cbe3a6c250c1e7 100644 --- a/metadata-ingestion/setup.py +++ b/metadata-ingestion/setup.py @@ -301,6 +301,7 @@ databricks = { # 0.1.11 appears to have authentication issues with azure databricks + # 0.22.0 has support for `include_browse` in metadata list apis "databricks-sdk>=0.30.0", "pyspark~=3.3.0", "requests", diff --git a/metadata-ingestion/src/datahub/ingestion/source/unity/hive_metastore_proxy.py b/metadata-ingestion/src/datahub/ingestion/source/unity/hive_metastore_proxy.py index c99fe3b09c5bb5..eea10d940bd1c8 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/unity/hive_metastore_proxy.py +++ b/metadata-ingestion/src/datahub/ingestion/source/unity/hive_metastore_proxy.py @@ -135,8 +135,8 @@ def get_table_names(self, schema_name: str) -> List[str]: def get_view_names(self, schema_name: str) -> List[str]: try: rows = self._execute_sql(f"SHOW VIEWS FROM `{schema_name}`") - # 3 columns - database, tableName, isTemporary - return [row.tableName for row in rows] + # 4 columns - namespace, viewName, isTemporary, isMaterialized + return [row.viewName for row in rows] except Exception as e: self.report.report_warning("Failed to get views for schema", schema_name) logger.warning( diff --git a/metadata-ingestion/src/datahub/ingestion/source/unity/proxy.py b/metadata-ingestion/src/datahub/ingestion/source/unity/proxy.py index 112acd8101297f..bd987c2da7c764 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/unity/proxy.py +++ b/metadata-ingestion/src/datahub/ingestion/source/unity/proxy.py @@ -109,7 +109,7 @@ def __init__( self.hive_metastore_proxy = hive_metastore_proxy def check_basic_connectivity(self) -> bool: - return bool(self._workspace_client.catalogs.list()) + return bool(self._workspace_client.catalogs.list(include_browse=True)) def assigned_metastore(self) -> Optional[Metastore]: response = self._workspace_client.metastores.summary() @@ -119,7 +119,7 @@ def catalogs(self, metastore: Optional[Metastore]) -> Iterable[Catalog]: if self.hive_metastore_proxy: yield self.hive_metastore_proxy.hive_metastore_catalog(metastore) - response = self._workspace_client.catalogs.list() + response = self._workspace_client.catalogs.list(include_browse=True) if not response: logger.info("Catalogs not found") return @@ -131,7 +131,9 @@ def catalogs(self, metastore: Optional[Metastore]) -> Iterable[Catalog]: def catalog( self, catalog_name: str, metastore: Optional[Metastore] ) -> Optional[Catalog]: - response = self._workspace_client.catalogs.get(catalog_name) + response = self._workspace_client.catalogs.get( + catalog_name, include_browse=True + ) if not response: logger.info(f"Catalog {catalog_name} not found") return None @@ -148,7 +150,9 @@ def schemas(self, catalog: Catalog) -> Iterable[Schema]: ): yield from self.hive_metastore_proxy.hive_metastore_schemas(catalog) return - response = self._workspace_client.schemas.list(catalog_name=catalog.name) + response = self._workspace_client.schemas.list( + catalog_name=catalog.name, include_browse=True + ) if not response: logger.info(f"Schemas not found for catalog {catalog.id}") return @@ -166,7 +170,9 @@ def tables(self, schema: Schema) -> Iterable[Table]: return with patch("databricks.sdk.service.catalog.TableInfo", TableInfoWithGeneration): response = self._workspace_client.tables.list( - catalog_name=schema.catalog.name, schema_name=schema.name + catalog_name=schema.catalog.name, + schema_name=schema.name, + include_browse=True, ) if not response: logger.info(f"Tables not found for schema {schema.id}") diff --git a/metadata-ingestion/tests/integration/unity/test_unity_catalog_ingest.py b/metadata-ingestion/tests/integration/unity/test_unity_catalog_ingest.py index 22a48efdec41d7..c078f1b77fd1be 100644 --- a/metadata-ingestion/tests/integration/unity/test_unity_catalog_ingest.py +++ b/metadata-ingestion/tests/integration/unity/test_unity_catalog_ingest.py @@ -276,6 +276,9 @@ def register_mock_data(workspace_client): TableEntry = namedtuple("TableEntry", ["database", "tableName", "isTemporary"]) +ViewEntry = namedtuple( + "ViewEntry", ["namespace", "viewName", "isTemporary", "isMaterialized"] +) def mock_hive_sql(query): @@ -418,7 +421,7 @@ def mock_hive_sql(query): TableEntry("bronze_kambi", "view1", False), ] elif query == "SHOW VIEWS FROM `bronze_kambi`": - return [TableEntry("bronze_kambi", "view1", False)] + return [ViewEntry("bronze_kambi", "view1", False, False)] return [] From eebb28a498d7b1240c32e91426d275963db42277 Mon Sep 17 00:00:00 2001 From: david-leifker <114954101+david-leifker@users.noreply.github.com> Date: Tue, 3 Sep 2024 12:14:00 -0500 Subject: [PATCH 07/34] fix(docs): fix logout url (#11294) --- docs/authentication/guides/sso/configure-oidc-react.md | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/docs/authentication/guides/sso/configure-oidc-react.md b/docs/authentication/guides/sso/configure-oidc-react.md index 9b4af80bb0ccd3..3676bbdfcc9b8c 100644 --- a/docs/authentication/guides/sso/configure-oidc-react.md +++ b/docs/authentication/guides/sso/configure-oidc-react.md @@ -48,7 +48,7 @@ Select `Web` as the **Platform**, and `OpenID Connect` as the **Sign on method** Click **Create** and name your application under **General Settings** and save. - **Login Redirect URI** : `https://your-datahub-domain.com/callback/oidc`. -- **Logout Redirect URI**. `https://your-datahub-domain.com` +- **Logout Redirect URI**. `https://your-datahub-domain.com/login`

From 96b075d79fc3afa5239a7d3974279106cf7801a8 Mon Sep 17 00:00:00 2001 From: Harshal Sheth Date: Tue, 3 Sep 2024 10:53:44 -0700 Subject: [PATCH 08/34] feat(ingest): add python deps for `apk` (#11188) --- docker/datahub-ingestion-base/Dockerfile | 2 +- metadata-ingestion/scripts/install_deps.sh | 8 +++++++- smoke-test/smoke.sh | 2 +- 3 files changed, 9 insertions(+), 3 deletions(-) diff --git a/docker/datahub-ingestion-base/Dockerfile b/docker/datahub-ingestion-base/Dockerfile index db1717ab59d163..92b17620998823 100644 --- a/docker/datahub-ingestion-base/Dockerfile +++ b/docker/datahub-ingestion-base/Dockerfile @@ -49,7 +49,7 @@ RUN apt-get update && apt-get upgrade -y \ ldap-utils \ unixodbc \ libodbc2 \ - && python -m pip install --no-cache --upgrade pip uv>=0.1.10 wheel setuptools \ + && python -m pip install --no-cache --upgrade pip 'uv>=0.1.10' wheel setuptools \ && apt-get clean \ && rm -rf /var/lib/{apt,dpkg,cache,log}/ diff --git a/metadata-ingestion/scripts/install_deps.sh b/metadata-ingestion/scripts/install_deps.sh index 80a07cb04cb447..bdc47f275742f4 100755 --- a/metadata-ingestion/scripts/install_deps.sh +++ b/metadata-ingestion/scripts/install_deps.sh @@ -19,7 +19,13 @@ else xz-devel \ libxml2-devel \ libxslt-devel \ - krb5-devel + krb5-devel + elif command -v apk; then + $sudo_cmd apk add \ + build-base \ + openldap-dev \ + xz-dev \ + krb5-dev else $sudo_cmd apt-get update && $sudo_cmd apt-get install -y \ python3-ldap \ diff --git a/smoke-test/smoke.sh b/smoke-test/smoke.sh index 5b3e8a9377a6ca..d74f77a4e624a1 100755 --- a/smoke-test/smoke.sh +++ b/smoke-test/smoke.sh @@ -23,7 +23,7 @@ else python3 -m venv venv source venv/bin/activate - python -m pip install --upgrade pip uv>=0.1.10 wheel setuptools + python -m pip install --upgrade pip 'uv>=0.1.10' wheel setuptools uv pip install -r requirements.txt fi From e34a628afe99ac4a74bd0568f6c270cc064cf9cd Mon Sep 17 00:00:00 2001 From: sleeperdeep <86791232+sleeperdeep@users.noreply.github.com> Date: Tue, 3 Sep 2024 22:41:23 +0300 Subject: [PATCH 09/34] fix(ingest/mssql): remove lower() method from sql_common get_db_name (#10773) --- docs/how/updating-datahub.md | 11 + .../ingestion/source/sql/sql_common.py | 2 +- .../golden_test_ingest_with_database.json | 138 ++-- .../golden_test_ingest_with_out_database.json | 114 +-- .../golden_mces_mssql_no_db_to_file.json | 686 +++++++++--------- .../golden_mces_mssql_no_db_with_filter.json | 362 ++++----- .../golden_mces_mssql_to_file.json | 362 ++++----- ...golden_mces_mssql_with_lower_case_urn.json | 362 ++++----- .../vertica/vertica_mces_with_db_golden.json | 510 ++++++------- 9 files changed, 1280 insertions(+), 1267 deletions(-) diff --git a/docs/how/updating-datahub.md b/docs/how/updating-datahub.md index 2443375099b7b2..293e39e735e013 100644 --- a/docs/how/updating-datahub.md +++ b/docs/how/updating-datahub.md @@ -19,6 +19,17 @@ This file documents any backwards-incompatible changes in DataHub and assists pe ## Next ### Breaking Changes +- #9857 (#10773) `lower` method was removed from `get_db_name` of `SQLAlchemySource` class. This change will affect the urns of all related to `SQLAlchemySource` entities. + + Old `urn`, where `data_base_name` is `Some_Database`: + ``` + - urn:li:dataJob:(urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD),Proc.With.SpecialChar) + ``` + New `urn`, where `data_base_name` is `Some_Database`: + ``` + - urn:li:dataJob:(urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD),Proc.With.SpecialChar) + ``` + Re-running with stateful ingestion should automatically clear up the entities with old URNS and add entities with new URNs, therefore not duplicating the containers or jobs. ### Potential Downtime diff --git a/metadata-ingestion/src/datahub/ingestion/source/sql/sql_common.py b/metadata-ingestion/src/datahub/ingestion/source/sql/sql_common.py index 2ab1e6bb41af1c..9ce50e21608843 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/sql/sql_common.py +++ b/metadata-ingestion/src/datahub/ingestion/source/sql/sql_common.py @@ -434,7 +434,7 @@ def get_db_name(self, inspector: Inspector) -> str: if engine and hasattr(engine, "url") and hasattr(engine.url, "database"): if engine.url.database is None: return "" - return str(engine.url.database).strip('"').lower() + return str(engine.url.database).strip('"') else: raise Exception("Unable to get database name from Sqlalchemy inspector") diff --git a/metadata-ingestion/tests/integration/oracle/golden_test_ingest_with_database.json b/metadata-ingestion/tests/integration/oracle/golden_test_ingest_with_database.json index 6732b17d2e8322..4054d757c22fdb 100644 --- a/metadata-ingestion/tests/integration/oracle/golden_test_ingest_with_database.json +++ b/metadata-ingestion/tests/integration/oracle/golden_test_ingest_with_database.json @@ -1,7 +1,7 @@ [ { "entityType": "container", - "entityUrn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", + "entityUrn": "urn:li:container:0e497517e191d344b0c403231bc708d0", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -9,9 +9,9 @@ "customProperties": { "platform": "oracle", "env": "PROD", - "database": "oradoc" + "database": "OraDoc" }, - "name": "oradoc" + "name": "OraDoc" } }, "systemMetadata": { @@ -22,7 +22,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", + "entityUrn": "urn:li:container:0e497517e191d344b0c403231bc708d0", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -38,7 +38,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", + "entityUrn": "urn:li:container:0e497517e191d344b0c403231bc708d0", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -54,7 +54,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", + "entityUrn": "urn:li:container:0e497517e191d344b0c403231bc708d0", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -72,7 +72,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", + "entityUrn": "urn:li:container:0e497517e191d344b0c403231bc708d0", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { @@ -88,7 +88,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c093e810646c7ebc493237bb24a3538f", + "entityUrn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -96,7 +96,7 @@ "customProperties": { "platform": "oracle", "env": "PROD", - "database": "oradoc", + "database": "OraDoc", "schema": "schema1" }, "name": "schema1" @@ -110,7 +110,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c093e810646c7ebc493237bb24a3538f", + "entityUrn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -126,7 +126,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c093e810646c7ebc493237bb24a3538f", + "entityUrn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -142,7 +142,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c093e810646c7ebc493237bb24a3538f", + "entityUrn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -160,12 +160,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c093e810646c7ebc493237bb24a3538f", + "entityUrn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "container": "urn:li:container:0e497517e191d344b0c403231bc708d0" } }, "systemMetadata": { @@ -176,15 +176,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c093e810646c7ebc493237bb24a3538f", + "entityUrn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", - "urn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "id": "urn:li:container:0e497517e191d344b0c403231bc708d0", + "urn": "urn:li:container:0e497517e191d344b0c403231bc708d0" } ] } @@ -202,7 +202,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:c093e810646c7ebc493237bb24a3538f" + "container": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad" } }, "systemMetadata": { @@ -301,12 +301,12 @@ "json": { "path": [ { - "id": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", - "urn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "id": "urn:li:container:0e497517e191d344b0c403231bc708d0", + "urn": "urn:li:container:0e497517e191d344b0c403231bc708d0" }, { - "id": "urn:li:container:c093e810646c7ebc493237bb24a3538f", - "urn": "urn:li:container:c093e810646c7ebc493237bb24a3538f" + "id": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", + "urn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad" } ] } @@ -324,7 +324,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:c093e810646c7ebc493237bb24a3538f" + "container": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad" } }, "systemMetadata": { @@ -423,12 +423,12 @@ "json": { "path": [ { - "id": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", - "urn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "id": "urn:li:container:0e497517e191d344b0c403231bc708d0", + "urn": "urn:li:container:0e497517e191d344b0c403231bc708d0" }, { - "id": "urn:li:container:c093e810646c7ebc493237bb24a3538f", - "urn": "urn:li:container:c093e810646c7ebc493237bb24a3538f" + "id": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", + "urn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad" } ] } @@ -446,7 +446,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:c093e810646c7ebc493237bb24a3538f" + "container": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad" } }, "systemMetadata": { @@ -566,12 +566,12 @@ "json": { "path": [ { - "id": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", - "urn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "id": "urn:li:container:0e497517e191d344b0c403231bc708d0", + "urn": "urn:li:container:0e497517e191d344b0c403231bc708d0" }, { - "id": "urn:li:container:c093e810646c7ebc493237bb24a3538f", - "urn": "urn:li:container:c093e810646c7ebc493237bb24a3538f" + "id": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", + "urn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad" } ] } @@ -584,7 +584,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", + "entityUrn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -592,7 +592,7 @@ "customProperties": { "platform": "oracle", "env": "PROD", - "database": "oradoc", + "database": "OraDoc", "schema": "schema2" }, "name": "schema2" @@ -606,7 +606,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", + "entityUrn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -622,7 +622,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", + "entityUrn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -638,7 +638,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", + "entityUrn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -656,12 +656,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", + "entityUrn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "container": "urn:li:container:0e497517e191d344b0c403231bc708d0" } }, "systemMetadata": { @@ -672,15 +672,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", + "entityUrn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", - "urn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "id": "urn:li:container:0e497517e191d344b0c403231bc708d0", + "urn": "urn:li:container:0e497517e191d344b0c403231bc708d0" } ] } @@ -698,7 +698,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825" + "container": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f" } }, "systemMetadata": { @@ -797,12 +797,12 @@ "json": { "path": [ { - "id": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", - "urn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "id": "urn:li:container:0e497517e191d344b0c403231bc708d0", + "urn": "urn:li:container:0e497517e191d344b0c403231bc708d0" }, { - "id": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", - "urn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825" + "id": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", + "urn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f" } ] } @@ -820,7 +820,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825" + "container": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f" } }, "systemMetadata": { @@ -919,12 +919,12 @@ "json": { "path": [ { - "id": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", - "urn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "id": "urn:li:container:0e497517e191d344b0c403231bc708d0", + "urn": "urn:li:container:0e497517e191d344b0c403231bc708d0" }, { - "id": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", - "urn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825" + "id": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", + "urn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f" } ] } @@ -942,7 +942,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825" + "container": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f" } }, "systemMetadata": { @@ -1062,12 +1062,12 @@ "json": { "path": [ { - "id": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", - "urn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "id": "urn:li:container:0e497517e191d344b0c403231bc708d0", + "urn": "urn:li:container:0e497517e191d344b0c403231bc708d0" }, { - "id": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", - "urn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825" + "id": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", + "urn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f" } ] } @@ -1080,7 +1080,7 @@ }, { "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema2.mock_view,PROD)", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema1.mock_view,PROD)", "changeType": "UPSERT", "aspectName": "upstreamLineage", "aspect": { @@ -1091,7 +1091,7 @@ "time": 0, "actor": "urn:li:corpuser:unknown" }, - "dataset": "urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema2.mock_table,PROD)", + "dataset": "urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema1.mock_table,PROD)", "type": "VIEW" } ], @@ -1099,22 +1099,22 @@ { "upstreamType": "FIELD_SET", "upstreams": [ - "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema2.mock_table,PROD),MOCK_COLUMN1)" + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema1.mock_table,PROD),MOCK_COLUMN1)" ], "downstreamType": "FIELD", "downstreams": [ - "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema2.mock_view,PROD),MOCK_COLUMN1)" + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema1.mock_view,PROD),MOCK_COLUMN1)" ], "confidenceScore": 1.0 }, { "upstreamType": "FIELD_SET", "upstreams": [ - "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema2.mock_table,PROD),MOCK_COLUMN2)" + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema1.mock_table,PROD),MOCK_COLUMN2)" ], "downstreamType": "FIELD", "downstreams": [ - "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema2.mock_view,PROD),MOCK_COLUMN2)" + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema1.mock_view,PROD),MOCK_COLUMN2)" ], "confidenceScore": 1.0 } @@ -1129,7 +1129,7 @@ }, { "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema1.mock_view,PROD)", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema2.mock_view,PROD)", "changeType": "UPSERT", "aspectName": "upstreamLineage", "aspect": { @@ -1140,7 +1140,7 @@ "time": 0, "actor": "urn:li:corpuser:unknown" }, - "dataset": "urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema1.mock_table,PROD)", + "dataset": "urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema2.mock_table,PROD)", "type": "VIEW" } ], @@ -1148,22 +1148,22 @@ { "upstreamType": "FIELD_SET", "upstreams": [ - "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema1.mock_table,PROD),MOCK_COLUMN1)" + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema2.mock_table,PROD),MOCK_COLUMN1)" ], "downstreamType": "FIELD", "downstreams": [ - "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema1.mock_view,PROD),MOCK_COLUMN1)" + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema2.mock_view,PROD),MOCK_COLUMN1)" ], "confidenceScore": 1.0 }, { "upstreamType": "FIELD_SET", "upstreams": [ - "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema1.mock_table,PROD),MOCK_COLUMN2)" + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema2.mock_table,PROD),MOCK_COLUMN2)" ], "downstreamType": "FIELD", "downstreams": [ - "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema1.mock_view,PROD),MOCK_COLUMN2)" + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:oracle,oradoc.schema2.mock_view,PROD),MOCK_COLUMN2)" ], "confidenceScore": 1.0 } diff --git a/metadata-ingestion/tests/integration/oracle/golden_test_ingest_with_out_database.json b/metadata-ingestion/tests/integration/oracle/golden_test_ingest_with_out_database.json index 7610daaa54b4a1..9df23078be18d4 100644 --- a/metadata-ingestion/tests/integration/oracle/golden_test_ingest_with_out_database.json +++ b/metadata-ingestion/tests/integration/oracle/golden_test_ingest_with_out_database.json @@ -1,7 +1,7 @@ [ { "entityType": "container", - "entityUrn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", + "entityUrn": "urn:li:container:0e497517e191d344b0c403231bc708d0", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -9,9 +9,9 @@ "customProperties": { "platform": "oracle", "env": "PROD", - "database": "oradoc" + "database": "OraDoc" }, - "name": "oradoc" + "name": "OraDoc" } }, "systemMetadata": { @@ -22,7 +22,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", + "entityUrn": "urn:li:container:0e497517e191d344b0c403231bc708d0", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -38,7 +38,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", + "entityUrn": "urn:li:container:0e497517e191d344b0c403231bc708d0", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -54,7 +54,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", + "entityUrn": "urn:li:container:0e497517e191d344b0c403231bc708d0", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -72,7 +72,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", + "entityUrn": "urn:li:container:0e497517e191d344b0c403231bc708d0", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { @@ -88,7 +88,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c093e810646c7ebc493237bb24a3538f", + "entityUrn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -96,7 +96,7 @@ "customProperties": { "platform": "oracle", "env": "PROD", - "database": "oradoc", + "database": "OraDoc", "schema": "schema1" }, "name": "schema1" @@ -110,7 +110,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c093e810646c7ebc493237bb24a3538f", + "entityUrn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -126,7 +126,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c093e810646c7ebc493237bb24a3538f", + "entityUrn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -142,7 +142,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c093e810646c7ebc493237bb24a3538f", + "entityUrn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -160,12 +160,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c093e810646c7ebc493237bb24a3538f", + "entityUrn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "container": "urn:li:container:0e497517e191d344b0c403231bc708d0" } }, "systemMetadata": { @@ -176,15 +176,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c093e810646c7ebc493237bb24a3538f", + "entityUrn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", - "urn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "id": "urn:li:container:0e497517e191d344b0c403231bc708d0", + "urn": "urn:li:container:0e497517e191d344b0c403231bc708d0" } ] } @@ -202,7 +202,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:c093e810646c7ebc493237bb24a3538f" + "container": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad" } }, "systemMetadata": { @@ -301,12 +301,12 @@ "json": { "path": [ { - "id": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", - "urn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "id": "urn:li:container:0e497517e191d344b0c403231bc708d0", + "urn": "urn:li:container:0e497517e191d344b0c403231bc708d0" }, { - "id": "urn:li:container:c093e810646c7ebc493237bb24a3538f", - "urn": "urn:li:container:c093e810646c7ebc493237bb24a3538f" + "id": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", + "urn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad" } ] } @@ -324,7 +324,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:c093e810646c7ebc493237bb24a3538f" + "container": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad" } }, "systemMetadata": { @@ -423,12 +423,12 @@ "json": { "path": [ { - "id": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", - "urn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "id": "urn:li:container:0e497517e191d344b0c403231bc708d0", + "urn": "urn:li:container:0e497517e191d344b0c403231bc708d0" }, { - "id": "urn:li:container:c093e810646c7ebc493237bb24a3538f", - "urn": "urn:li:container:c093e810646c7ebc493237bb24a3538f" + "id": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", + "urn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad" } ] } @@ -446,7 +446,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:c093e810646c7ebc493237bb24a3538f" + "container": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad" } }, "systemMetadata": { @@ -566,12 +566,12 @@ "json": { "path": [ { - "id": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", - "urn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "id": "urn:li:container:0e497517e191d344b0c403231bc708d0", + "urn": "urn:li:container:0e497517e191d344b0c403231bc708d0" }, { - "id": "urn:li:container:c093e810646c7ebc493237bb24a3538f", - "urn": "urn:li:container:c093e810646c7ebc493237bb24a3538f" + "id": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad", + "urn": "urn:li:container:937a38ee28b69ecae38665c5e842d0ad" } ] } @@ -584,7 +584,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", + "entityUrn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -592,7 +592,7 @@ "customProperties": { "platform": "oracle", "env": "PROD", - "database": "oradoc", + "database": "OraDoc", "schema": "schema2" }, "name": "schema2" @@ -606,7 +606,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", + "entityUrn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -622,7 +622,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", + "entityUrn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -638,7 +638,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", + "entityUrn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -656,12 +656,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", + "entityUrn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "container": "urn:li:container:0e497517e191d344b0c403231bc708d0" } }, "systemMetadata": { @@ -672,15 +672,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", + "entityUrn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", - "urn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "id": "urn:li:container:0e497517e191d344b0c403231bc708d0", + "urn": "urn:li:container:0e497517e191d344b0c403231bc708d0" } ] } @@ -698,7 +698,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825" + "container": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f" } }, "systemMetadata": { @@ -797,12 +797,12 @@ "json": { "path": [ { - "id": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", - "urn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "id": "urn:li:container:0e497517e191d344b0c403231bc708d0", + "urn": "urn:li:container:0e497517e191d344b0c403231bc708d0" }, { - "id": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", - "urn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825" + "id": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", + "urn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f" } ] } @@ -820,7 +820,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825" + "container": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f" } }, "systemMetadata": { @@ -919,12 +919,12 @@ "json": { "path": [ { - "id": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", - "urn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "id": "urn:li:container:0e497517e191d344b0c403231bc708d0", + "urn": "urn:li:container:0e497517e191d344b0c403231bc708d0" }, { - "id": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", - "urn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825" + "id": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", + "urn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f" } ] } @@ -942,7 +942,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825" + "container": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f" } }, "systemMetadata": { @@ -1062,12 +1062,12 @@ "json": { "path": [ { - "id": "urn:li:container:8c867b02fcc2615b19cd02b15b023287", - "urn": "urn:li:container:8c867b02fcc2615b19cd02b15b023287" + "id": "urn:li:container:0e497517e191d344b0c403231bc708d0", + "urn": "urn:li:container:0e497517e191d344b0c403231bc708d0" }, { - "id": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825", - "urn": "urn:li:container:ab1a240f35ae787df0eff0e6726a9825" + "id": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f", + "urn": "urn:li:container:1965527855ae77f259a8ddea2b8eed2f" } ] } diff --git a/metadata-ingestion/tests/integration/sql_server/golden_files/golden_mces_mssql_no_db_to_file.json b/metadata-ingestion/tests/integration/sql_server/golden_files/golden_mces_mssql_no_db_to_file.json index 74cb216117bd43..1213f78e274868 100644 --- a/metadata-ingestion/tests/integration/sql_server/golden_files/golden_mces_mssql_no_db_to_file.json +++ b/metadata-ingestion/tests/integration/sql_server/golden_files/golden_mces_mssql_no_db_to_file.json @@ -1,7 +1,7 @@ [ { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -9,9 +9,9 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata" + "database": "DemoData" }, - "name": "demodata" + "name": "DemoData" } }, "systemMetadata": { @@ -22,7 +22,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -38,7 +38,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -54,7 +54,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -72,7 +72,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { @@ -112,11 +112,11 @@ "aspect": { "json": { "customProperties": { - "job_id": "c6fb6778-14f1-4516-bb41-e5eaa97a687b", + "job_id": "a7684ed9-7d4c-46f2-b8bd-1dc5941345d0", "job_name": "Weekly Demo Data Backup", "description": "No description available.", - "date_created": "2024-07-27 23:58:29.780000", - "date_modified": "2024-07-27 23:58:29.943000", + "date_created": "2024-09-03 11:56:19.400000", + "date_modified": "2024-09-03 11:56:19.580000", "step_id": "1", "step_name": "Set database to read only", "subsystem": "TSQL", @@ -155,7 +155,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -163,7 +163,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_accessadmin" }, "name": "db_accessadmin" @@ -177,7 +177,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -193,7 +193,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -209,7 +209,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -227,12 +227,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -243,15 +243,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -264,7 +264,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -272,7 +272,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_backupoperator" }, "name": "db_backupoperator" @@ -286,7 +286,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -302,7 +302,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -318,7 +318,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -336,12 +336,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -352,15 +352,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -373,7 +373,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -381,7 +381,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_datareader" }, "name": "db_datareader" @@ -395,7 +395,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -411,7 +411,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -427,7 +427,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -445,12 +445,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -461,15 +461,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -482,7 +482,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -490,7 +490,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_datawriter" }, "name": "db_datawriter" @@ -504,7 +504,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -520,7 +520,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -536,7 +536,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -554,12 +554,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -570,15 +570,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -591,7 +591,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -599,7 +599,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_ddladmin" }, "name": "db_ddladmin" @@ -613,7 +613,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -629,7 +629,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -645,7 +645,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -663,12 +663,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -679,15 +679,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -700,7 +700,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -708,7 +708,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_denydatareader" }, "name": "db_denydatareader" @@ -722,7 +722,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -738,7 +738,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -754,7 +754,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -772,12 +772,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -788,15 +788,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -809,7 +809,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -817,7 +817,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_denydatawriter" }, "name": "db_denydatawriter" @@ -831,7 +831,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -847,7 +847,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -863,7 +863,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -881,12 +881,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -897,15 +897,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -918,7 +918,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -926,7 +926,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_owner" }, "name": "db_owner" @@ -940,7 +940,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -956,7 +956,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -972,7 +972,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -990,12 +990,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -1006,15 +1006,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -1027,7 +1027,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -1035,7 +1035,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_securityadmin" }, "name": "db_securityadmin" @@ -1049,7 +1049,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -1065,7 +1065,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -1081,7 +1081,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -1099,12 +1099,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -1115,15 +1115,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -1136,7 +1136,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -1144,7 +1144,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "dbo" }, "name": "dbo" @@ -1158,7 +1158,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -1174,7 +1174,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -1190,7 +1190,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -1208,12 +1208,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -1224,15 +1224,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -1250,7 +1250,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec" + "container": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1" } }, "systemMetadata": { @@ -1359,12 +1359,12 @@ "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" }, { - "id": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", - "urn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec" + "id": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", + "urn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1" } ] } @@ -1377,7 +1377,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -1385,7 +1385,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "Foo" }, "name": "Foo" @@ -1399,7 +1399,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -1415,7 +1415,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -1431,7 +1431,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -1449,12 +1449,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -1465,15 +1465,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -1491,7 +1491,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "container": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } }, "systemMetadata": { @@ -1601,12 +1601,12 @@ "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" }, { - "id": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", - "urn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "id": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", + "urn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } ] } @@ -1624,7 +1624,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "container": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } }, "systemMetadata": { @@ -1758,12 +1758,12 @@ "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" }, { - "id": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", - "urn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "id": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", + "urn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } ] } @@ -1781,7 +1781,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "container": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } }, "systemMetadata": { @@ -1914,12 +1914,12 @@ "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" }, { - "id": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", - "urn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "id": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", + "urn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } ] } @@ -1932,14 +1932,14 @@ }, { "entityType": "dataFlow", - "entityUrn": "urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD)", + "entityUrn": "urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD)", "changeType": "UPSERT", "aspectName": "dataFlowInfo", "aspect": { "json": { "customProperties": {}, "externalUrl": "", - "name": "demodata.Foo.stored_procedures" + "name": "DemoData.Foo.stored_procedures" } }, "systemMetadata": { @@ -1950,7 +1950,7 @@ }, { "entityType": "dataJob", - "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", + "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", "changeType": "UPSERT", "aspectName": "dataJobInfo", "aspect": { @@ -1961,11 +1961,11 @@ "code": "CREATE PROCEDURE [Foo].[Proc.With.SpecialChar] @ID INT\nAS\n SELECT @ID AS ThatDB;\n", "input parameters": "['@ID']", "parameter @ID": "{'type': 'int'}", - "date_created": "2024-07-27 23:58:29.703000", - "date_modified": "2024-07-27 23:58:29.703000" + "date_created": "2024-09-03 11:56:19.310000", + "date_modified": "2024-09-03 11:56:19.310000" }, "externalUrl": "", - "name": "demodata.Foo.Proc.With.SpecialChar", + "name": "DemoData.Foo.Proc.With.SpecialChar", "type": { "string": "MSSQL_STORED_PROCEDURE" } @@ -1979,7 +1979,7 @@ }, { "entityType": "dataJob", - "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", + "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", "changeType": "UPSERT", "aspectName": "dataJobInputOutput", "aspect": { @@ -1997,7 +1997,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2005,7 +2005,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "guest" }, "name": "guest" @@ -2019,7 +2019,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2035,7 +2035,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2051,7 +2051,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2069,12 +2069,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -2085,15 +2085,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -2106,7 +2106,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2114,7 +2114,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "INFORMATION_SCHEMA" }, "name": "INFORMATION_SCHEMA" @@ -2128,7 +2128,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2144,7 +2144,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2160,7 +2160,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2178,12 +2178,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -2194,15 +2194,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -2215,7 +2215,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2223,7 +2223,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "sys" }, "name": "sys" @@ -2237,7 +2237,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2253,7 +2253,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2269,7 +2269,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2287,12 +2287,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -2303,15 +2303,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -2324,7 +2324,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", + "entityUrn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2332,9 +2332,9 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "newdata" + "database": "NewData" }, - "name": "newdata" + "name": "NewData" } }, "systemMetadata": { @@ -2345,7 +2345,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", + "entityUrn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2361,7 +2361,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", + "entityUrn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2377,7 +2377,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", + "entityUrn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2395,7 +2395,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", + "entityUrn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { @@ -2411,7 +2411,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:47217386c89d8b94153f6ee31e7e77ec", + "entityUrn": "urn:li:container:8b7691fec458d7383d5bc4e213831375", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2419,7 +2419,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "newdata", + "database": "NewData", "schema": "db_accessadmin" }, "name": "db_accessadmin" @@ -2433,7 +2433,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:47217386c89d8b94153f6ee31e7e77ec", + "entityUrn": "urn:li:container:8b7691fec458d7383d5bc4e213831375", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2449,7 +2449,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:47217386c89d8b94153f6ee31e7e77ec", + "entityUrn": "urn:li:container:8b7691fec458d7383d5bc4e213831375", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2465,7 +2465,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:47217386c89d8b94153f6ee31e7e77ec", + "entityUrn": "urn:li:container:8b7691fec458d7383d5bc4e213831375", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2483,12 +2483,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:47217386c89d8b94153f6ee31e7e77ec", + "entityUrn": "urn:li:container:8b7691fec458d7383d5bc4e213831375", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "container": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } }, "systemMetadata": { @@ -2499,15 +2499,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:47217386c89d8b94153f6ee31e7e77ec", + "entityUrn": "urn:li:container:8b7691fec458d7383d5bc4e213831375", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } ] } @@ -2520,7 +2520,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:5eb0d61efa998d1ccd5cbdc6ce4bb4af", + "entityUrn": "urn:li:container:523d13eddd725607ec835a2459b05c9c", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2528,7 +2528,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "newdata", + "database": "NewData", "schema": "db_backupoperator" }, "name": "db_backupoperator" @@ -2542,7 +2542,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:5eb0d61efa998d1ccd5cbdc6ce4bb4af", + "entityUrn": "urn:li:container:523d13eddd725607ec835a2459b05c9c", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2558,7 +2558,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:5eb0d61efa998d1ccd5cbdc6ce4bb4af", + "entityUrn": "urn:li:container:523d13eddd725607ec835a2459b05c9c", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2574,7 +2574,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:5eb0d61efa998d1ccd5cbdc6ce4bb4af", + "entityUrn": "urn:li:container:523d13eddd725607ec835a2459b05c9c", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2592,12 +2592,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:5eb0d61efa998d1ccd5cbdc6ce4bb4af", + "entityUrn": "urn:li:container:523d13eddd725607ec835a2459b05c9c", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "container": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } }, "systemMetadata": { @@ -2608,15 +2608,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:5eb0d61efa998d1ccd5cbdc6ce4bb4af", + "entityUrn": "urn:li:container:523d13eddd725607ec835a2459b05c9c", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } ] } @@ -2629,7 +2629,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2816b2cb7f90d3dce64125ba89fb1fa8", + "entityUrn": "urn:li:container:29bd421b2225a415df9c750e77404c66", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2637,7 +2637,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "newdata", + "database": "NewData", "schema": "db_datareader" }, "name": "db_datareader" @@ -2651,7 +2651,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2816b2cb7f90d3dce64125ba89fb1fa8", + "entityUrn": "urn:li:container:29bd421b2225a415df9c750e77404c66", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2667,7 +2667,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2816b2cb7f90d3dce64125ba89fb1fa8", + "entityUrn": "urn:li:container:29bd421b2225a415df9c750e77404c66", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2683,7 +2683,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2816b2cb7f90d3dce64125ba89fb1fa8", + "entityUrn": "urn:li:container:29bd421b2225a415df9c750e77404c66", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2701,12 +2701,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2816b2cb7f90d3dce64125ba89fb1fa8", + "entityUrn": "urn:li:container:29bd421b2225a415df9c750e77404c66", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "container": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } }, "systemMetadata": { @@ -2717,15 +2717,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2816b2cb7f90d3dce64125ba89fb1fa8", + "entityUrn": "urn:li:container:29bd421b2225a415df9c750e77404c66", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } ] } @@ -2738,7 +2738,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:20d0f0c94e9796ff44ff32d4d0e19084", + "entityUrn": "urn:li:container:a3c02df4bcc7280a89f539b793b04197", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2746,7 +2746,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "newdata", + "database": "NewData", "schema": "db_datawriter" }, "name": "db_datawriter" @@ -2760,7 +2760,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:20d0f0c94e9796ff44ff32d4d0e19084", + "entityUrn": "urn:li:container:a3c02df4bcc7280a89f539b793b04197", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2776,7 +2776,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:20d0f0c94e9796ff44ff32d4d0e19084", + "entityUrn": "urn:li:container:a3c02df4bcc7280a89f539b793b04197", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2792,7 +2792,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:20d0f0c94e9796ff44ff32d4d0e19084", + "entityUrn": "urn:li:container:a3c02df4bcc7280a89f539b793b04197", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2810,12 +2810,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:20d0f0c94e9796ff44ff32d4d0e19084", + "entityUrn": "urn:li:container:a3c02df4bcc7280a89f539b793b04197", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "container": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } }, "systemMetadata": { @@ -2826,15 +2826,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:20d0f0c94e9796ff44ff32d4d0e19084", + "entityUrn": "urn:li:container:a3c02df4bcc7280a89f539b793b04197", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } ] } @@ -2847,7 +2847,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3600d2ebb33b25dac607624d7eae7575", + "entityUrn": "urn:li:container:c3b5d1cdc69a7d8faf0e1981e89b89d1", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2855,7 +2855,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "newdata", + "database": "NewData", "schema": "db_ddladmin" }, "name": "db_ddladmin" @@ -2869,7 +2869,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3600d2ebb33b25dac607624d7eae7575", + "entityUrn": "urn:li:container:c3b5d1cdc69a7d8faf0e1981e89b89d1", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2885,7 +2885,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3600d2ebb33b25dac607624d7eae7575", + "entityUrn": "urn:li:container:c3b5d1cdc69a7d8faf0e1981e89b89d1", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2901,7 +2901,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3600d2ebb33b25dac607624d7eae7575", + "entityUrn": "urn:li:container:c3b5d1cdc69a7d8faf0e1981e89b89d1", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2919,12 +2919,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3600d2ebb33b25dac607624d7eae7575", + "entityUrn": "urn:li:container:c3b5d1cdc69a7d8faf0e1981e89b89d1", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "container": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } }, "systemMetadata": { @@ -2935,15 +2935,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3600d2ebb33b25dac607624d7eae7575", + "entityUrn": "urn:li:container:c3b5d1cdc69a7d8faf0e1981e89b89d1", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } ] } @@ -2956,7 +2956,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:280f2e3aefacc346d0ce1590ec337c7d", + "entityUrn": "urn:li:container:2b937d85ae7545dc769766008a332f42", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2964,7 +2964,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "newdata", + "database": "NewData", "schema": "db_denydatareader" }, "name": "db_denydatareader" @@ -2978,7 +2978,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:280f2e3aefacc346d0ce1590ec337c7d", + "entityUrn": "urn:li:container:2b937d85ae7545dc769766008a332f42", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2994,7 +2994,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:280f2e3aefacc346d0ce1590ec337c7d", + "entityUrn": "urn:li:container:2b937d85ae7545dc769766008a332f42", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -3010,7 +3010,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:280f2e3aefacc346d0ce1590ec337c7d", + "entityUrn": "urn:li:container:2b937d85ae7545dc769766008a332f42", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -3028,12 +3028,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:280f2e3aefacc346d0ce1590ec337c7d", + "entityUrn": "urn:li:container:2b937d85ae7545dc769766008a332f42", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "container": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } }, "systemMetadata": { @@ -3044,15 +3044,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:280f2e3aefacc346d0ce1590ec337c7d", + "entityUrn": "urn:li:container:2b937d85ae7545dc769766008a332f42", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } ] } @@ -3065,7 +3065,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:cba5c3ca7f028fcf749593be369d3c24", + "entityUrn": "urn:li:container:a399d8bb765028abb9e55ae39846ca5e", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -3073,7 +3073,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "newdata", + "database": "NewData", "schema": "db_denydatawriter" }, "name": "db_denydatawriter" @@ -3087,7 +3087,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:cba5c3ca7f028fcf749593be369d3c24", + "entityUrn": "urn:li:container:a399d8bb765028abb9e55ae39846ca5e", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -3103,7 +3103,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:cba5c3ca7f028fcf749593be369d3c24", + "entityUrn": "urn:li:container:a399d8bb765028abb9e55ae39846ca5e", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -3119,7 +3119,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:cba5c3ca7f028fcf749593be369d3c24", + "entityUrn": "urn:li:container:a399d8bb765028abb9e55ae39846ca5e", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -3137,12 +3137,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:cba5c3ca7f028fcf749593be369d3c24", + "entityUrn": "urn:li:container:a399d8bb765028abb9e55ae39846ca5e", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "container": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } }, "systemMetadata": { @@ -3153,15 +3153,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:cba5c3ca7f028fcf749593be369d3c24", + "entityUrn": "urn:li:container:a399d8bb765028abb9e55ae39846ca5e", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } ] } @@ -3174,7 +3174,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:58c30fa72f213ca7e12fb04f5a7d150f", + "entityUrn": "urn:li:container:457efe38f0aec2af9ad681cf1b43b1cb", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -3182,7 +3182,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "newdata", + "database": "NewData", "schema": "db_owner" }, "name": "db_owner" @@ -3196,7 +3196,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:58c30fa72f213ca7e12fb04f5a7d150f", + "entityUrn": "urn:li:container:457efe38f0aec2af9ad681cf1b43b1cb", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -3212,7 +3212,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:58c30fa72f213ca7e12fb04f5a7d150f", + "entityUrn": "urn:li:container:457efe38f0aec2af9ad681cf1b43b1cb", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -3228,7 +3228,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:58c30fa72f213ca7e12fb04f5a7d150f", + "entityUrn": "urn:li:container:457efe38f0aec2af9ad681cf1b43b1cb", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -3246,12 +3246,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:58c30fa72f213ca7e12fb04f5a7d150f", + "entityUrn": "urn:li:container:457efe38f0aec2af9ad681cf1b43b1cb", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "container": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } }, "systemMetadata": { @@ -3262,15 +3262,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:58c30fa72f213ca7e12fb04f5a7d150f", + "entityUrn": "urn:li:container:457efe38f0aec2af9ad681cf1b43b1cb", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } ] } @@ -3283,7 +3283,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9387ddfeb7b57672cabd761ade89c49c", + "entityUrn": "urn:li:container:1d87783ffe7e82210365dff4ca8ee7d1", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -3291,7 +3291,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "newdata", + "database": "NewData", "schema": "db_securityadmin" }, "name": "db_securityadmin" @@ -3305,7 +3305,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9387ddfeb7b57672cabd761ade89c49c", + "entityUrn": "urn:li:container:1d87783ffe7e82210365dff4ca8ee7d1", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -3321,7 +3321,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9387ddfeb7b57672cabd761ade89c49c", + "entityUrn": "urn:li:container:1d87783ffe7e82210365dff4ca8ee7d1", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -3337,7 +3337,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9387ddfeb7b57672cabd761ade89c49c", + "entityUrn": "urn:li:container:1d87783ffe7e82210365dff4ca8ee7d1", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -3355,12 +3355,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9387ddfeb7b57672cabd761ade89c49c", + "entityUrn": "urn:li:container:1d87783ffe7e82210365dff4ca8ee7d1", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "container": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } }, "systemMetadata": { @@ -3371,15 +3371,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9387ddfeb7b57672cabd761ade89c49c", + "entityUrn": "urn:li:container:1d87783ffe7e82210365dff4ca8ee7d1", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } ] } @@ -3392,7 +3392,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3a5f70e0e34834d4eeeb4d5a5caf03d0", + "entityUrn": "urn:li:container:269d0067d130eda0399a534fc787054c", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -3400,7 +3400,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "newdata", + "database": "NewData", "schema": "dbo" }, "name": "dbo" @@ -3414,7 +3414,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3a5f70e0e34834d4eeeb4d5a5caf03d0", + "entityUrn": "urn:li:container:269d0067d130eda0399a534fc787054c", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -3430,7 +3430,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3a5f70e0e34834d4eeeb4d5a5caf03d0", + "entityUrn": "urn:li:container:269d0067d130eda0399a534fc787054c", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -3446,7 +3446,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3a5f70e0e34834d4eeeb4d5a5caf03d0", + "entityUrn": "urn:li:container:269d0067d130eda0399a534fc787054c", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -3464,12 +3464,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3a5f70e0e34834d4eeeb4d5a5caf03d0", + "entityUrn": "urn:li:container:269d0067d130eda0399a534fc787054c", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "container": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } }, "systemMetadata": { @@ -3480,15 +3480,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3a5f70e0e34834d4eeeb4d5a5caf03d0", + "entityUrn": "urn:li:container:269d0067d130eda0399a534fc787054c", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } ] } @@ -3506,7 +3506,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:3a5f70e0e34834d4eeeb4d5a5caf03d0" + "container": "urn:li:container:269d0067d130eda0399a534fc787054c" } }, "systemMetadata": { @@ -3627,12 +3627,12 @@ "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" }, { - "id": "urn:li:container:3a5f70e0e34834d4eeeb4d5a5caf03d0", - "urn": "urn:li:container:3a5f70e0e34834d4eeeb4d5a5caf03d0" + "id": "urn:li:container:269d0067d130eda0399a534fc787054c", + "urn": "urn:li:container:269d0067d130eda0399a534fc787054c" } ] } @@ -3645,7 +3645,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:7cc43e5b4e2a7f2f66f1df774d1a0c63", + "entityUrn": "urn:li:container:f721da08adde46586c0f113287cb60d1", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -3653,7 +3653,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "newdata", + "database": "NewData", "schema": "FooNew" }, "name": "FooNew" @@ -3667,7 +3667,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:7cc43e5b4e2a7f2f66f1df774d1a0c63", + "entityUrn": "urn:li:container:f721da08adde46586c0f113287cb60d1", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -3683,7 +3683,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:7cc43e5b4e2a7f2f66f1df774d1a0c63", + "entityUrn": "urn:li:container:f721da08adde46586c0f113287cb60d1", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -3699,7 +3699,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:7cc43e5b4e2a7f2f66f1df774d1a0c63", + "entityUrn": "urn:li:container:f721da08adde46586c0f113287cb60d1", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -3717,12 +3717,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:7cc43e5b4e2a7f2f66f1df774d1a0c63", + "entityUrn": "urn:li:container:f721da08adde46586c0f113287cb60d1", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "container": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } }, "systemMetadata": { @@ -3733,15 +3733,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:7cc43e5b4e2a7f2f66f1df774d1a0c63", + "entityUrn": "urn:li:container:f721da08adde46586c0f113287cb60d1", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } ] } @@ -3759,7 +3759,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:7cc43e5b4e2a7f2f66f1df774d1a0c63" + "container": "urn:li:container:f721da08adde46586c0f113287cb60d1" } }, "systemMetadata": { @@ -3880,12 +3880,12 @@ "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" }, { - "id": "urn:li:container:7cc43e5b4e2a7f2f66f1df774d1a0c63", - "urn": "urn:li:container:7cc43e5b4e2a7f2f66f1df774d1a0c63" + "id": "urn:li:container:f721da08adde46586c0f113287cb60d1", + "urn": "urn:li:container:f721da08adde46586c0f113287cb60d1" } ] } @@ -3903,7 +3903,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:7cc43e5b4e2a7f2f66f1df774d1a0c63" + "container": "urn:li:container:f721da08adde46586c0f113287cb60d1" } }, "systemMetadata": { @@ -4036,12 +4036,12 @@ "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" }, { - "id": "urn:li:container:7cc43e5b4e2a7f2f66f1df774d1a0c63", - "urn": "urn:li:container:7cc43e5b4e2a7f2f66f1df774d1a0c63" + "id": "urn:li:container:f721da08adde46586c0f113287cb60d1", + "urn": "urn:li:container:f721da08adde46586c0f113287cb60d1" } ] } @@ -4054,7 +4054,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:54727d9fd7deacef27641559125bbc56", + "entityUrn": "urn:li:container:f3cb304e29e178d0615ed5ee6aa4ad58", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -4062,7 +4062,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "newdata", + "database": "NewData", "schema": "guest" }, "name": "guest" @@ -4076,7 +4076,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:54727d9fd7deacef27641559125bbc56", + "entityUrn": "urn:li:container:f3cb304e29e178d0615ed5ee6aa4ad58", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -4092,7 +4092,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:54727d9fd7deacef27641559125bbc56", + "entityUrn": "urn:li:container:f3cb304e29e178d0615ed5ee6aa4ad58", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -4108,7 +4108,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:54727d9fd7deacef27641559125bbc56", + "entityUrn": "urn:li:container:f3cb304e29e178d0615ed5ee6aa4ad58", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -4126,12 +4126,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:54727d9fd7deacef27641559125bbc56", + "entityUrn": "urn:li:container:f3cb304e29e178d0615ed5ee6aa4ad58", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "container": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } }, "systemMetadata": { @@ -4142,15 +4142,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:54727d9fd7deacef27641559125bbc56", + "entityUrn": "urn:li:container:f3cb304e29e178d0615ed5ee6aa4ad58", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } ] } @@ -4163,7 +4163,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:141b0980dcb08f48544583e47cf48807", + "entityUrn": "urn:li:container:752bb2abafeb2dae8f4adc7ffd547780", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -4171,7 +4171,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "newdata", + "database": "NewData", "schema": "INFORMATION_SCHEMA" }, "name": "INFORMATION_SCHEMA" @@ -4185,7 +4185,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:141b0980dcb08f48544583e47cf48807", + "entityUrn": "urn:li:container:752bb2abafeb2dae8f4adc7ffd547780", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -4201,7 +4201,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:141b0980dcb08f48544583e47cf48807", + "entityUrn": "urn:li:container:752bb2abafeb2dae8f4adc7ffd547780", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -4217,7 +4217,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:141b0980dcb08f48544583e47cf48807", + "entityUrn": "urn:li:container:752bb2abafeb2dae8f4adc7ffd547780", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -4235,12 +4235,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:141b0980dcb08f48544583e47cf48807", + "entityUrn": "urn:li:container:752bb2abafeb2dae8f4adc7ffd547780", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "container": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } }, "systemMetadata": { @@ -4251,15 +4251,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:141b0980dcb08f48544583e47cf48807", + "entityUrn": "urn:li:container:752bb2abafeb2dae8f4adc7ffd547780", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } ] } @@ -4272,7 +4272,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c6627af82d44de89492e1a9315ae9f4b", + "entityUrn": "urn:li:container:46b713e3c7754c51649899f0f284ce34", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -4280,7 +4280,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "newdata", + "database": "NewData", "schema": "sys" }, "name": "sys" @@ -4294,7 +4294,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c6627af82d44de89492e1a9315ae9f4b", + "entityUrn": "urn:li:container:46b713e3c7754c51649899f0f284ce34", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -4310,7 +4310,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c6627af82d44de89492e1a9315ae9f4b", + "entityUrn": "urn:li:container:46b713e3c7754c51649899f0f284ce34", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -4326,7 +4326,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c6627af82d44de89492e1a9315ae9f4b", + "entityUrn": "urn:li:container:46b713e3c7754c51649899f0f284ce34", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -4344,12 +4344,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c6627af82d44de89492e1a9315ae9f4b", + "entityUrn": "urn:li:container:46b713e3c7754c51649899f0f284ce34", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "container": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } }, "systemMetadata": { @@ -4360,15 +4360,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:c6627af82d44de89492e1a9315ae9f4b", + "entityUrn": "urn:li:container:46b713e3c7754c51649899f0f284ce34", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59", - "urn": "urn:li:container:9447d283fb4f95ce7474f1db0179bb59" + "id": "urn:li:container:0a12bec9e9271b0db039923a770d75e5", + "urn": "urn:li:container:0a12bec9e9271b0db039923a770d75e5" } ] } @@ -4381,7 +4381,7 @@ }, { "entityType": "dataFlow", - "entityUrn": "urn:li:dataFlow:(mssql,Weekly Demo Data Backup,PROD)", + "entityUrn": "urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD)", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -4397,7 +4397,7 @@ }, { "entityType": "dataFlow", - "entityUrn": "urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD)", + "entityUrn": "urn:li:dataFlow:(mssql,Weekly Demo Data Backup,PROD)", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -4413,7 +4413,7 @@ }, { "entityType": "dataJob", - "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,Weekly Demo Data Backup,PROD),Weekly Demo Data Backup)", + "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -4429,7 +4429,7 @@ }, { "entityType": "dataJob", - "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", + "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,Weekly Demo Data Backup,PROD),Weekly Demo Data Backup)", "changeType": "UPSERT", "aspectName": "status", "aspect": { diff --git a/metadata-ingestion/tests/integration/sql_server/golden_files/golden_mces_mssql_no_db_with_filter.json b/metadata-ingestion/tests/integration/sql_server/golden_files/golden_mces_mssql_no_db_with_filter.json index e1af3f72a8af1f..7c854fb1bdde81 100644 --- a/metadata-ingestion/tests/integration/sql_server/golden_files/golden_mces_mssql_no_db_with_filter.json +++ b/metadata-ingestion/tests/integration/sql_server/golden_files/golden_mces_mssql_no_db_with_filter.json @@ -1,7 +1,7 @@ [ { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -9,9 +9,9 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata" + "database": "DemoData" }, - "name": "demodata" + "name": "DemoData" } }, "systemMetadata": { @@ -22,7 +22,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -38,7 +38,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -54,7 +54,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -72,7 +72,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { @@ -112,11 +112,11 @@ "aspect": { "json": { "customProperties": { - "job_id": "c6fb6778-14f1-4516-bb41-e5eaa97a687b", + "job_id": "a7684ed9-7d4c-46f2-b8bd-1dc5941345d0", "job_name": "Weekly Demo Data Backup", "description": "No description available.", - "date_created": "2024-07-27 23:58:29.780000", - "date_modified": "2024-07-27 23:58:29.943000", + "date_created": "2024-09-03 11:56:19.400000", + "date_modified": "2024-09-03 11:56:19.580000", "step_id": "1", "step_name": "Set database to read only", "subsystem": "TSQL", @@ -155,7 +155,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -163,7 +163,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_accessadmin" }, "name": "db_accessadmin" @@ -177,7 +177,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -193,7 +193,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -209,7 +209,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -227,12 +227,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -243,15 +243,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -264,7 +264,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -272,7 +272,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_backupoperator" }, "name": "db_backupoperator" @@ -286,7 +286,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -302,7 +302,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -318,7 +318,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -336,12 +336,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -352,15 +352,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -373,7 +373,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -381,7 +381,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_datareader" }, "name": "db_datareader" @@ -395,7 +395,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -411,7 +411,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -427,7 +427,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -445,12 +445,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -461,15 +461,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -482,7 +482,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -490,7 +490,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_datawriter" }, "name": "db_datawriter" @@ -504,7 +504,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -520,7 +520,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -536,7 +536,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -554,12 +554,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -570,15 +570,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -591,7 +591,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -599,7 +599,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_ddladmin" }, "name": "db_ddladmin" @@ -613,7 +613,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -629,7 +629,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -645,7 +645,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -663,12 +663,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -679,15 +679,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -700,7 +700,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -708,7 +708,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_denydatareader" }, "name": "db_denydatareader" @@ -722,7 +722,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -738,7 +738,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -754,7 +754,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -772,12 +772,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -788,15 +788,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -809,7 +809,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -817,7 +817,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_denydatawriter" }, "name": "db_denydatawriter" @@ -831,7 +831,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -847,7 +847,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -863,7 +863,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -881,12 +881,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -897,15 +897,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -918,7 +918,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -926,7 +926,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_owner" }, "name": "db_owner" @@ -940,7 +940,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -956,7 +956,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -972,7 +972,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -990,12 +990,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -1006,15 +1006,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -1027,7 +1027,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -1035,7 +1035,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_securityadmin" }, "name": "db_securityadmin" @@ -1049,7 +1049,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -1065,7 +1065,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -1081,7 +1081,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -1099,12 +1099,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -1115,15 +1115,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -1136,7 +1136,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -1144,7 +1144,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "dbo" }, "name": "dbo" @@ -1158,7 +1158,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -1174,7 +1174,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -1190,7 +1190,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -1208,12 +1208,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -1224,15 +1224,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -1250,7 +1250,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec" + "container": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1" } }, "systemMetadata": { @@ -1359,12 +1359,12 @@ "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" }, { - "id": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", - "urn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec" + "id": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", + "urn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1" } ] } @@ -1377,7 +1377,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -1385,7 +1385,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "Foo" }, "name": "Foo" @@ -1399,7 +1399,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -1415,7 +1415,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -1431,7 +1431,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -1449,12 +1449,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -1465,15 +1465,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -1491,7 +1491,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "container": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } }, "systemMetadata": { @@ -1601,12 +1601,12 @@ "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" }, { - "id": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", - "urn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "id": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", + "urn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } ] } @@ -1624,7 +1624,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "container": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } }, "systemMetadata": { @@ -1758,12 +1758,12 @@ "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" }, { - "id": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", - "urn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "id": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", + "urn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } ] } @@ -1781,7 +1781,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "container": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } }, "systemMetadata": { @@ -1914,12 +1914,12 @@ "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" }, { - "id": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", - "urn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "id": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", + "urn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } ] } @@ -1932,14 +1932,14 @@ }, { "entityType": "dataFlow", - "entityUrn": "urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD)", + "entityUrn": "urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD)", "changeType": "UPSERT", "aspectName": "dataFlowInfo", "aspect": { "json": { "customProperties": {}, "externalUrl": "", - "name": "demodata.Foo.stored_procedures" + "name": "DemoData.Foo.stored_procedures" } }, "systemMetadata": { @@ -1950,7 +1950,7 @@ }, { "entityType": "dataJob", - "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", + "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", "changeType": "UPSERT", "aspectName": "dataJobInfo", "aspect": { @@ -1961,11 +1961,11 @@ "code": "CREATE PROCEDURE [Foo].[Proc.With.SpecialChar] @ID INT\nAS\n SELECT @ID AS ThatDB;\n", "input parameters": "['@ID']", "parameter @ID": "{'type': 'int'}", - "date_created": "2024-07-27 23:58:29.703000", - "date_modified": "2024-07-27 23:58:29.703000" + "date_created": "2024-09-03 11:56:19.310000", + "date_modified": "2024-09-03 11:56:19.310000" }, "externalUrl": "", - "name": "demodata.Foo.Proc.With.SpecialChar", + "name": "DemoData.Foo.Proc.With.SpecialChar", "type": { "string": "MSSQL_STORED_PROCEDURE" } @@ -1979,7 +1979,7 @@ }, { "entityType": "dataJob", - "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", + "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", "changeType": "UPSERT", "aspectName": "dataJobInputOutput", "aspect": { @@ -1997,7 +1997,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2005,7 +2005,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "guest" }, "name": "guest" @@ -2019,7 +2019,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2035,7 +2035,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2051,7 +2051,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2069,12 +2069,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -2085,15 +2085,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -2106,7 +2106,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2114,7 +2114,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "INFORMATION_SCHEMA" }, "name": "INFORMATION_SCHEMA" @@ -2128,7 +2128,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2144,7 +2144,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2160,7 +2160,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2178,12 +2178,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -2194,15 +2194,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -2215,7 +2215,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2223,7 +2223,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "sys" }, "name": "sys" @@ -2237,7 +2237,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2253,7 +2253,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2269,7 +2269,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2287,12 +2287,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -2303,15 +2303,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -2324,7 +2324,7 @@ }, { "entityType": "dataFlow", - "entityUrn": "urn:li:dataFlow:(mssql,Weekly Demo Data Backup,PROD)", + "entityUrn": "urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD)", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2340,7 +2340,7 @@ }, { "entityType": "dataFlow", - "entityUrn": "urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD)", + "entityUrn": "urn:li:dataFlow:(mssql,Weekly Demo Data Backup,PROD)", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2356,7 +2356,7 @@ }, { "entityType": "dataJob", - "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,Weekly Demo Data Backup,PROD),Weekly Demo Data Backup)", + "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2372,7 +2372,7 @@ }, { "entityType": "dataJob", - "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", + "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,Weekly Demo Data Backup,PROD),Weekly Demo Data Backup)", "changeType": "UPSERT", "aspectName": "status", "aspect": { diff --git a/metadata-ingestion/tests/integration/sql_server/golden_files/golden_mces_mssql_to_file.json b/metadata-ingestion/tests/integration/sql_server/golden_files/golden_mces_mssql_to_file.json index e1af3f72a8af1f..7c854fb1bdde81 100644 --- a/metadata-ingestion/tests/integration/sql_server/golden_files/golden_mces_mssql_to_file.json +++ b/metadata-ingestion/tests/integration/sql_server/golden_files/golden_mces_mssql_to_file.json @@ -1,7 +1,7 @@ [ { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -9,9 +9,9 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata" + "database": "DemoData" }, - "name": "demodata" + "name": "DemoData" } }, "systemMetadata": { @@ -22,7 +22,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -38,7 +38,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -54,7 +54,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -72,7 +72,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { @@ -112,11 +112,11 @@ "aspect": { "json": { "customProperties": { - "job_id": "c6fb6778-14f1-4516-bb41-e5eaa97a687b", + "job_id": "a7684ed9-7d4c-46f2-b8bd-1dc5941345d0", "job_name": "Weekly Demo Data Backup", "description": "No description available.", - "date_created": "2024-07-27 23:58:29.780000", - "date_modified": "2024-07-27 23:58:29.943000", + "date_created": "2024-09-03 11:56:19.400000", + "date_modified": "2024-09-03 11:56:19.580000", "step_id": "1", "step_name": "Set database to read only", "subsystem": "TSQL", @@ -155,7 +155,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -163,7 +163,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_accessadmin" }, "name": "db_accessadmin" @@ -177,7 +177,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -193,7 +193,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -209,7 +209,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -227,12 +227,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -243,15 +243,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -264,7 +264,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -272,7 +272,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_backupoperator" }, "name": "db_backupoperator" @@ -286,7 +286,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -302,7 +302,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -318,7 +318,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -336,12 +336,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -352,15 +352,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -373,7 +373,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -381,7 +381,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_datareader" }, "name": "db_datareader" @@ -395,7 +395,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -411,7 +411,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -427,7 +427,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -445,12 +445,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -461,15 +461,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -482,7 +482,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -490,7 +490,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_datawriter" }, "name": "db_datawriter" @@ -504,7 +504,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -520,7 +520,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -536,7 +536,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -554,12 +554,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -570,15 +570,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -591,7 +591,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -599,7 +599,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_ddladmin" }, "name": "db_ddladmin" @@ -613,7 +613,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -629,7 +629,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -645,7 +645,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -663,12 +663,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -679,15 +679,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -700,7 +700,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -708,7 +708,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_denydatareader" }, "name": "db_denydatareader" @@ -722,7 +722,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -738,7 +738,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -754,7 +754,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -772,12 +772,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -788,15 +788,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -809,7 +809,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -817,7 +817,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_denydatawriter" }, "name": "db_denydatawriter" @@ -831,7 +831,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -847,7 +847,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -863,7 +863,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -881,12 +881,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -897,15 +897,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -918,7 +918,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -926,7 +926,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_owner" }, "name": "db_owner" @@ -940,7 +940,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -956,7 +956,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -972,7 +972,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -990,12 +990,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -1006,15 +1006,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -1027,7 +1027,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -1035,7 +1035,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_securityadmin" }, "name": "db_securityadmin" @@ -1049,7 +1049,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -1065,7 +1065,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -1081,7 +1081,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -1099,12 +1099,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -1115,15 +1115,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -1136,7 +1136,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -1144,7 +1144,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "dbo" }, "name": "dbo" @@ -1158,7 +1158,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -1174,7 +1174,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -1190,7 +1190,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -1208,12 +1208,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -1224,15 +1224,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -1250,7 +1250,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec" + "container": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1" } }, "systemMetadata": { @@ -1359,12 +1359,12 @@ "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" }, { - "id": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", - "urn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec" + "id": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", + "urn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1" } ] } @@ -1377,7 +1377,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -1385,7 +1385,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "Foo" }, "name": "Foo" @@ -1399,7 +1399,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -1415,7 +1415,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -1431,7 +1431,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -1449,12 +1449,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -1465,15 +1465,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -1491,7 +1491,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "container": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } }, "systemMetadata": { @@ -1601,12 +1601,12 @@ "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" }, { - "id": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", - "urn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "id": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", + "urn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } ] } @@ -1624,7 +1624,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "container": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } }, "systemMetadata": { @@ -1758,12 +1758,12 @@ "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" }, { - "id": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", - "urn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "id": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", + "urn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } ] } @@ -1781,7 +1781,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "container": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } }, "systemMetadata": { @@ -1914,12 +1914,12 @@ "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" }, { - "id": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", - "urn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "id": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", + "urn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } ] } @@ -1932,14 +1932,14 @@ }, { "entityType": "dataFlow", - "entityUrn": "urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD)", + "entityUrn": "urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD)", "changeType": "UPSERT", "aspectName": "dataFlowInfo", "aspect": { "json": { "customProperties": {}, "externalUrl": "", - "name": "demodata.Foo.stored_procedures" + "name": "DemoData.Foo.stored_procedures" } }, "systemMetadata": { @@ -1950,7 +1950,7 @@ }, { "entityType": "dataJob", - "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", + "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", "changeType": "UPSERT", "aspectName": "dataJobInfo", "aspect": { @@ -1961,11 +1961,11 @@ "code": "CREATE PROCEDURE [Foo].[Proc.With.SpecialChar] @ID INT\nAS\n SELECT @ID AS ThatDB;\n", "input parameters": "['@ID']", "parameter @ID": "{'type': 'int'}", - "date_created": "2024-07-27 23:58:29.703000", - "date_modified": "2024-07-27 23:58:29.703000" + "date_created": "2024-09-03 11:56:19.310000", + "date_modified": "2024-09-03 11:56:19.310000" }, "externalUrl": "", - "name": "demodata.Foo.Proc.With.SpecialChar", + "name": "DemoData.Foo.Proc.With.SpecialChar", "type": { "string": "MSSQL_STORED_PROCEDURE" } @@ -1979,7 +1979,7 @@ }, { "entityType": "dataJob", - "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", + "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", "changeType": "UPSERT", "aspectName": "dataJobInputOutput", "aspect": { @@ -1997,7 +1997,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2005,7 +2005,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "guest" }, "name": "guest" @@ -2019,7 +2019,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2035,7 +2035,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2051,7 +2051,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2069,12 +2069,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -2085,15 +2085,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -2106,7 +2106,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2114,7 +2114,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "INFORMATION_SCHEMA" }, "name": "INFORMATION_SCHEMA" @@ -2128,7 +2128,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2144,7 +2144,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2160,7 +2160,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2178,12 +2178,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -2194,15 +2194,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -2215,7 +2215,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2223,7 +2223,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "sys" }, "name": "sys" @@ -2237,7 +2237,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2253,7 +2253,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2269,7 +2269,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2287,12 +2287,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -2303,15 +2303,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -2324,7 +2324,7 @@ }, { "entityType": "dataFlow", - "entityUrn": "urn:li:dataFlow:(mssql,Weekly Demo Data Backup,PROD)", + "entityUrn": "urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD)", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2340,7 +2340,7 @@ }, { "entityType": "dataFlow", - "entityUrn": "urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD)", + "entityUrn": "urn:li:dataFlow:(mssql,Weekly Demo Data Backup,PROD)", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2356,7 +2356,7 @@ }, { "entityType": "dataJob", - "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,Weekly Demo Data Backup,PROD),Weekly Demo Data Backup)", + "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2372,7 +2372,7 @@ }, { "entityType": "dataJob", - "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", + "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,Weekly Demo Data Backup,PROD),Weekly Demo Data Backup)", "changeType": "UPSERT", "aspectName": "status", "aspect": { diff --git a/metadata-ingestion/tests/integration/sql_server/golden_files/golden_mces_mssql_with_lower_case_urn.json b/metadata-ingestion/tests/integration/sql_server/golden_files/golden_mces_mssql_with_lower_case_urn.json index 5b936c0d9f2446..1d971624939f8b 100644 --- a/metadata-ingestion/tests/integration/sql_server/golden_files/golden_mces_mssql_with_lower_case_urn.json +++ b/metadata-ingestion/tests/integration/sql_server/golden_files/golden_mces_mssql_with_lower_case_urn.json @@ -1,7 +1,7 @@ [ { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -9,9 +9,9 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata" + "database": "DemoData" }, - "name": "demodata" + "name": "DemoData" } }, "systemMetadata": { @@ -22,7 +22,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -38,7 +38,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -54,7 +54,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -72,7 +72,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", + "entityUrn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { @@ -112,11 +112,11 @@ "aspect": { "json": { "customProperties": { - "job_id": "c6fb6778-14f1-4516-bb41-e5eaa97a687b", + "job_id": "a7684ed9-7d4c-46f2-b8bd-1dc5941345d0", "job_name": "Weekly Demo Data Backup", "description": "No description available.", - "date_created": "2024-07-27 23:58:29.780000", - "date_modified": "2024-07-27 23:58:29.943000", + "date_created": "2024-09-03 11:56:19.400000", + "date_modified": "2024-09-03 11:56:19.580000", "step_id": "1", "step_name": "Set database to read only", "subsystem": "TSQL", @@ -155,7 +155,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -163,7 +163,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_accessadmin" }, "name": "db_accessadmin" @@ -177,7 +177,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -193,7 +193,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -209,7 +209,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -227,12 +227,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -243,15 +243,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:f1b4c0e379c4b2e2e09a8ecd6c1b6dec", + "entityUrn": "urn:li:container:7da983a1581c33cce8a106587b150f02", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -264,7 +264,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -272,7 +272,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_backupoperator" }, "name": "db_backupoperator" @@ -286,7 +286,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -302,7 +302,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -318,7 +318,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -336,12 +336,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -352,15 +352,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:bad84e08ecf49aee863df68243d8b9d0", + "entityUrn": "urn:li:container:671f67227a05c22c9fa97c27abc56820", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -373,7 +373,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -381,7 +381,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_datareader" }, "name": "db_datareader" @@ -395,7 +395,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -411,7 +411,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -427,7 +427,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -445,12 +445,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -461,15 +461,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:e48d82445eeacfbe13b431f0bb1826ee", + "entityUrn": "urn:li:container:830660638ee785d5352ca300835af7ec", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -482,7 +482,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -490,7 +490,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_datawriter" }, "name": "db_datawriter" @@ -504,7 +504,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -520,7 +520,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -536,7 +536,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -554,12 +554,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -570,15 +570,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:884bfecd9e414990a494681293413e8e", + "entityUrn": "urn:li:container:e6b69ac2a511e798a89a4186881f70b8", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -591,7 +591,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -599,7 +599,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_ddladmin" }, "name": "db_ddladmin" @@ -613,7 +613,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -629,7 +629,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -645,7 +645,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -663,12 +663,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -679,15 +679,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:142ca5fc51b7f44e5e6a424bf1043590", + "entityUrn": "urn:li:container:a5b29b900882d27c0d5fb0d5ccac92a5", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -700,7 +700,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -708,7 +708,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_denydatareader" }, "name": "db_denydatareader" @@ -722,7 +722,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -738,7 +738,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -754,7 +754,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -772,12 +772,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -788,15 +788,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:1b9d125d390447de36719bfb8dd1f782", + "entityUrn": "urn:li:container:b6baf19c5f148fba3d3385151a8c672f", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -809,7 +809,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -817,7 +817,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_denydatawriter" }, "name": "db_denydatawriter" @@ -831,7 +831,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -847,7 +847,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -863,7 +863,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -881,12 +881,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -897,15 +897,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:fcd4c8da3739150766f91e7f6c2a3a30", + "entityUrn": "urn:li:container:ee19bd6cf8db0a0d086fbe78f7539bf7", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -918,7 +918,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -926,7 +926,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_owner" }, "name": "db_owner" @@ -940,7 +940,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -956,7 +956,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -972,7 +972,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -990,12 +990,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -1006,15 +1006,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:2029cab615b3cd82cb87b153957d2e92", + "entityUrn": "urn:li:container:6514a64e5b04f103c9c1dd0ebe3d8b47", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -1027,7 +1027,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -1035,7 +1035,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "db_securityadmin" }, "name": "db_securityadmin" @@ -1049,7 +1049,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -1065,7 +1065,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -1081,7 +1081,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -1099,12 +1099,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -1115,15 +1115,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:556e25ccec98892284f017f870ef7809", + "entityUrn": "urn:li:container:fd80008628a03642d6e747c460a90619", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -1136,7 +1136,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -1144,7 +1144,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "dbo" }, "name": "dbo" @@ -1158,7 +1158,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -1174,7 +1174,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -1190,7 +1190,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -1208,12 +1208,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -1224,15 +1224,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", + "entityUrn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -1250,7 +1250,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec" + "container": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1" } }, "systemMetadata": { @@ -1359,12 +1359,12 @@ "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" }, { - "id": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec", - "urn": "urn:li:container:d41a036a2e6cfa44b834edf7683199ec" + "id": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1", + "urn": "urn:li:container:61332a50b978d8ca7245ddb34565d7b1" } ] } @@ -1377,7 +1377,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -1385,7 +1385,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "Foo" }, "name": "Foo" @@ -1399,7 +1399,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -1415,7 +1415,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -1431,7 +1431,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -1449,12 +1449,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -1465,15 +1465,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", + "entityUrn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -1491,7 +1491,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "container": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } }, "systemMetadata": { @@ -1601,12 +1601,12 @@ "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" }, { - "id": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", - "urn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "id": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", + "urn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } ] } @@ -1624,7 +1624,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "container": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } }, "systemMetadata": { @@ -1758,12 +1758,12 @@ "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" }, { - "id": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", - "urn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "id": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", + "urn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } ] } @@ -1781,7 +1781,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "container": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } }, "systemMetadata": { @@ -1914,12 +1914,12 @@ "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" }, { - "id": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671", - "urn": "urn:li:container:6e5c6d608d0a2dcc4eb03591382e5671" + "id": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9", + "urn": "urn:li:container:046d11ae7c0bc9bde45993041ac011c9" } ] } @@ -1932,14 +1932,14 @@ }, { "entityType": "dataFlow", - "entityUrn": "urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD)", + "entityUrn": "urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD)", "changeType": "UPSERT", "aspectName": "dataFlowInfo", "aspect": { "json": { "customProperties": {}, "externalUrl": "", - "name": "demodata.Foo.stored_procedures" + "name": "DemoData.Foo.stored_procedures" } }, "systemMetadata": { @@ -1950,7 +1950,7 @@ }, { "entityType": "dataJob", - "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", + "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", "changeType": "UPSERT", "aspectName": "dataJobInfo", "aspect": { @@ -1961,11 +1961,11 @@ "code": "CREATE PROCEDURE [Foo].[Proc.With.SpecialChar] @ID INT\nAS\n SELECT @ID AS ThatDB;\n", "input parameters": "['@ID']", "parameter @ID": "{'type': 'int'}", - "date_created": "2024-07-27 23:58:29.703000", - "date_modified": "2024-07-27 23:58:29.703000" + "date_created": "2024-09-03 11:56:19.310000", + "date_modified": "2024-09-03 11:56:19.310000" }, "externalUrl": "", - "name": "demodata.Foo.Proc.With.SpecialChar", + "name": "DemoData.Foo.Proc.With.SpecialChar", "type": { "string": "MSSQL_STORED_PROCEDURE" } @@ -1979,7 +1979,7 @@ }, { "entityType": "dataJob", - "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", + "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", "changeType": "UPSERT", "aspectName": "dataJobInputOutput", "aspect": { @@ -1997,7 +1997,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2005,7 +2005,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "guest" }, "name": "guest" @@ -2019,7 +2019,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2035,7 +2035,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2051,7 +2051,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2069,12 +2069,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -2085,15 +2085,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:a6bea84fba7b05fb5d12630c8e6306ac", + "entityUrn": "urn:li:container:250ce23f940485303fa5e5d4f5194975", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -2106,7 +2106,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2114,7 +2114,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "INFORMATION_SCHEMA" }, "name": "INFORMATION_SCHEMA" @@ -2128,7 +2128,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2144,7 +2144,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2160,7 +2160,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2178,12 +2178,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -2194,15 +2194,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:9f37bb7baa7ded19cc023e9f644a8cf8", + "entityUrn": "urn:li:container:f84e3b6c61876e1625f9112cbc0e988f", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -2215,7 +2215,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -2223,7 +2223,7 @@ "customProperties": { "platform": "mssql", "env": "PROD", - "database": "demodata", + "database": "DemoData", "schema": "sys" }, "name": "sys" @@ -2237,7 +2237,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2253,7 +2253,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -2269,7 +2269,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -2287,12 +2287,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "container": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } }, "systemMetadata": { @@ -2303,15 +2303,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:3f157d8292fb473142f19e2250af537f", + "entityUrn": "urn:li:container:d730a6ecf30bbb41cac5df5c0014168d", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5", - "urn": "urn:li:container:b7062d1c0c650d9de0f7a9a5de00b1b5" + "id": "urn:li:container:b275b7c099ce32f3faf1817cb054b100", + "urn": "urn:li:container:b275b7c099ce32f3faf1817cb054b100" } ] } @@ -2324,7 +2324,7 @@ }, { "entityType": "dataFlow", - "entityUrn": "urn:li:dataFlow:(mssql,Weekly Demo Data Backup,PROD)", + "entityUrn": "urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD)", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2340,7 +2340,7 @@ }, { "entityType": "dataFlow", - "entityUrn": "urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD)", + "entityUrn": "urn:li:dataFlow:(mssql,Weekly Demo Data Backup,PROD)", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2356,7 +2356,7 @@ }, { "entityType": "dataJob", - "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,Weekly Demo Data Backup,PROD),Weekly Demo Data Backup)", + "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,DemoData.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -2372,7 +2372,7 @@ }, { "entityType": "dataJob", - "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,demodata.Foo.stored_procedures,PROD),Proc.With.SpecialChar)", + "entityUrn": "urn:li:dataJob:(urn:li:dataFlow:(mssql,Weekly Demo Data Backup,PROD),Weekly Demo Data Backup)", "changeType": "UPSERT", "aspectName": "status", "aspect": { diff --git a/metadata-ingestion/tests/integration/vertica/vertica_mces_with_db_golden.json b/metadata-ingestion/tests/integration/vertica/vertica_mces_with_db_golden.json index b7e0f268aa7fe1..2f2a02a3352ee1 100644 --- a/metadata-ingestion/tests/integration/vertica/vertica_mces_with_db_golden.json +++ b/metadata-ingestion/tests/integration/vertica/vertica_mces_with_db_golden.json @@ -1,7 +1,7 @@ [ { "entityType": "container", - "entityUrn": "urn:li:container:343f520ad0fb3259b298736800bb1385", + "entityUrn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -9,9 +9,9 @@ "customProperties": { "platform": "vertica", "env": "PROD", - "database": "vmart" + "database": "Vmart" }, - "name": "vmart" + "name": "Vmart" } }, "systemMetadata": { @@ -22,7 +22,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:343f520ad0fb3259b298736800bb1385", + "entityUrn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -38,7 +38,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:343f520ad0fb3259b298736800bb1385", + "entityUrn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -54,7 +54,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:343f520ad0fb3259b298736800bb1385", + "entityUrn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -72,7 +72,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:343f520ad0fb3259b298736800bb1385", + "entityUrn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { @@ -88,7 +88,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", + "entityUrn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -96,7 +96,7 @@ "customProperties": { "platform": "vertica", "env": "PROD", - "database": "vmart", + "database": "Vmart", "schema": "public" }, "name": "public" @@ -110,7 +110,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", + "entityUrn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -126,7 +126,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", + "entityUrn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -142,7 +142,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", + "entityUrn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -160,12 +160,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", + "entityUrn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "container": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" } }, "systemMetadata": { @@ -176,15 +176,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", + "entityUrn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" } ] } @@ -228,7 +228,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -356,12 +356,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -405,7 +405,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -767,12 +767,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -816,7 +816,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -1178,12 +1178,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -1227,7 +1227,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -1550,12 +1550,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -1599,7 +1599,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -1766,12 +1766,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -1815,7 +1815,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -1917,12 +1917,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -1966,7 +1966,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -2328,12 +2328,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -2377,7 +2377,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -2622,12 +2622,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -2671,7 +2671,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -2799,12 +2799,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -2848,7 +2848,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -2989,12 +2989,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -3038,7 +3038,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -3231,12 +3231,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -3280,7 +3280,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -3382,12 +3382,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -3431,7 +3431,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -3598,12 +3598,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -3647,7 +3647,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -3782,12 +3782,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -3800,7 +3800,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:342b43fc61f85b16580be55c11e89787", + "entityUrn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -3808,7 +3808,8 @@ "customProperties": { "platform": "vertica", "env": "PROD", - "database": "vmart", + "database": "Vmart", + "database": "Vmart", "schema": "store" }, "name": "store" @@ -3822,7 +3823,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:342b43fc61f85b16580be55c11e89787", + "entityUrn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -3838,7 +3839,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:342b43fc61f85b16580be55c11e89787", + "entityUrn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -3854,7 +3855,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:342b43fc61f85b16580be55c11e89787", + "entityUrn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -3872,12 +3873,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:342b43fc61f85b16580be55c11e89787", + "entityUrn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "container": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" } }, "systemMetadata": { @@ -3888,15 +3889,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:342b43fc61f85b16580be55c11e89787", + "entityUrn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" } ] } @@ -3940,7 +3941,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:342b43fc61f85b16580be55c11e89787" + "container": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44" } }, "systemMetadata": { @@ -4263,12 +4264,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:342b43fc61f85b16580be55c11e89787", - "urn": "urn:li:container:342b43fc61f85b16580be55c11e89787" + "id": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", + "urn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44" } ] } @@ -4312,7 +4313,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:342b43fc61f85b16580be55c11e89787" + "container": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44" } }, "systemMetadata": { @@ -4648,12 +4649,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:342b43fc61f85b16580be55c11e89787", - "urn": "urn:li:container:342b43fc61f85b16580be55c11e89787" + "id": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", + "urn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44" } ] } @@ -4697,7 +4698,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:342b43fc61f85b16580be55c11e89787" + "container": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44" } }, "systemMetadata": { @@ -5007,12 +5008,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:342b43fc61f85b16580be55c11e89787", - "urn": "urn:li:container:342b43fc61f85b16580be55c11e89787" + "id": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", + "urn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44" } ] } @@ -5025,7 +5026,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", + "entityUrn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -5033,7 +5034,7 @@ "customProperties": { "platform": "vertica", "env": "PROD", - "database": "vmart", + "database": "Vmart", "schema": "online_sales" }, "name": "online_sales" @@ -5047,7 +5048,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", + "entityUrn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5063,7 +5064,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", + "entityUrn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -5079,7 +5080,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", + "entityUrn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -5097,12 +5098,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", + "entityUrn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "container": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" } }, "systemMetadata": { @@ -5113,15 +5114,15 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", + "entityUrn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", "changeType": "UPSERT", "aspectName": "browsePathsV2", "aspect": { "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" } ] } @@ -5165,7 +5166,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:ae8df3182db1bb8b3a612998126beae7" + "container": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557" } }, "systemMetadata": { @@ -5410,12 +5411,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", - "urn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7" + "id": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", + "urn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557" } ] } @@ -5459,7 +5460,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:ae8df3182db1bb8b3a612998126beae7" + "container": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557" } }, "systemMetadata": { @@ -5626,12 +5627,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", - "urn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7" + "id": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", + "urn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557" } ] } @@ -5675,7 +5676,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:ae8df3182db1bb8b3a612998126beae7" + "container": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557" } }, "systemMetadata": { @@ -6024,12 +6025,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", - "urn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7" + "id": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", + "urn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557" } ] } @@ -6042,7 +6043,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:343f520ad0fb3259b298736800bb1385", + "entityUrn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -6050,13 +6051,14 @@ "customProperties": { "platform": "vertica", "env": "PROD", - "database": "vmart", + "database": "Vmart", + "database": "Vmart", "cluster_type": "Enterprise", "cluster_size": "243 GB", "subcluster": " ", "communal_storage_path": "" }, - "name": "vmart" + "name": "Vmart" } }, "systemMetadata": { @@ -6067,7 +6069,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:343f520ad0fb3259b298736800bb1385", + "entityUrn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -6083,7 +6085,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:343f520ad0fb3259b298736800bb1385", + "entityUrn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -6099,7 +6101,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:343f520ad0fb3259b298736800bb1385", + "entityUrn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -6117,7 +6119,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", + "entityUrn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -6125,7 +6127,7 @@ "customProperties": { "platform": "vertica", "env": "PROD", - "database": "vmart", + "database": "Vmart", "schema": "public", "projection_count": "12", "udx_list": "APPROXIMATE_COUNT_DISTINCT_SYNOPSIS_INFO, APPROXIMATE_MEDIAN, APPROXIMATE_PERCENTILE, AcdDataToCount, AcdDataToLongSyn, AcdDataToSyn, AcdSynToCount, AcdSynToSyn, DelimitedExport, DelimitedExportMulti, EmptyMap, Explode, FAvroParser, FCefParser, FCsvParser, FDelimitedPairParser, FDelimitedParser, FIDXParser, FJSONParser, FRegexParser, FlexTokenizer, JsonExport, JsonExportMulti, KafkaAvroParser, KafkaCheckBrokers, KafkaExport, KafkaInsertDelimiters, KafkaInsertLengths, KafkaJsonParser, KafkaListManyTopics, KafkaListTopics, KafkaOffsets, KafkaParser, KafkaSource, KafkaTopicDetails, MSE, MapAggregate, MapAggregate, MapContainsKey, MapContainsKey, MapContainsValue, MapContainsValue, MapDelimitedExtractor, MapItems, MapItems, MapJSONExtractor, MapKeys, MapKeys, MapKeysInfo, MapKeysInfo, MapLookup, MapLookup, MapLookup, MapPut, MapRegexExtractor, MapSize, MapSize, MapToString, MapToString, MapValues, MapValues, MapValuesOrField, MapVersion, MapVersion, OrcExport, OrcExportMulti, PRC, ParquetExport, ParquetExportMulti, PickBestType, PickBestType, PickBestType, ROC, STV_AsGeoJSON, STV_AsGeoJSON, STV_AsGeoJSON, STV_Create_Index, STV_Create_Index, STV_Create_Index, STV_DWithin, STV_DWithin, STV_DWithin, STV_Describe_Index, STV_Drop_Index, STV_Export2Shapefile, STV_Extent, STV_Extent, STV_ForceLHR, STV_Geography, STV_Geography, STV_GeographyPoint, STV_Geometry, STV_Geometry, STV_GeometryPoint, STV_GeometryPoint, STV_GetExportShapefileDirectory, STV_Intersect, STV_Intersect, STV_Intersect, STV_Intersect, STV_Intersect, STV_Intersect, STV_Intersect, STV_Intersect, STV_IsValidReason, STV_IsValidReason, STV_IsValidReason, STV_LineStringPoint, STV_LineStringPoint, STV_LineStringPoint, STV_MemSize, STV_MemSize, STV_MemSize, STV_NN, STV_NN, STV_NN, STV_PolygonPoint, STV_PolygonPoint, STV_PolygonPoint, STV_Refresh_Index, STV_Refresh_Index, STV_Refresh_Index, STV_Rename_Index, STV_Reverse, STV_SetExportShapefileDirectory, STV_ShpCreateTable, STV_ShpParser, STV_ShpSource, ST_Area, ST_Area, ST_Area, ST_AsBinary, ST_AsBinary, ST_AsBinary, ST_AsText, ST_AsText, ST_AsText, ST_Boundary, ST_Buffer, ST_Centroid, ST_Contains, ST_Contains, ST_Contains, ST_ConvexHull, ST_Crosses, ST_Difference, ST_Disjoint, ST_Disjoint, ST_Disjoint, ST_Distance, ST_Distance, ST_Distance, ST_Envelope, ST_Equals, ST_Equals, ST_Equals, ST_GeoHash, ST_GeoHash, ST_GeoHash, ST_GeographyFromText, ST_GeographyFromWKB, ST_GeomFromGeoHash, ST_GeomFromGeoJSON, ST_GeomFromGeoJSON, ST_GeomFromText, ST_GeomFromText, ST_GeomFromWKB, ST_GeomFromWKB, ST_GeometryN, ST_GeometryN, ST_GeometryN, ST_GeometryType, ST_GeometryType, ST_GeometryType, ST_Intersection, ST_Intersects, ST_Intersects, ST_IsEmpty, ST_IsEmpty, ST_IsEmpty, ST_IsSimple, ST_IsSimple, ST_IsSimple, ST_IsValid, ST_IsValid, ST_IsValid, ST_Length, ST_Length, ST_Length, ST_NumGeometries, ST_NumGeometries, ST_NumGeometries, ST_NumPoints, ST_NumPoints, ST_NumPoints, ST_Overlaps, ST_PointFromGeoHash, ST_PointN, ST_PointN, ST_PointN, ST_Relate, ST_SRID, ST_SRID, ST_SRID, ST_Simplify, ST_SimplifyPreserveTopology, ST_SymDifference, ST_Touches, ST_Touches, ST_Touches, ST_Transform, ST_Union, ST_Union, ST_Within, ST_Within, ST_Within, ST_X, ST_X, ST_X, ST_XMax, ST_XMax, ST_XMax, ST_XMin, ST_XMin, ST_XMin, ST_Y, ST_Y, ST_Y, ST_YMax, ST_YMax, ST_YMax, ST_YMin, ST_YMin, ST_YMin, ST_intersects, SetMapKeys, Summarize_CatCol, Summarize_CatCol, Summarize_CatCol, Summarize_CatCol, Summarize_CatCol, Summarize_NumCol, Unnest, VoltageSecureAccess, VoltageSecureAccess, VoltageSecureConfigure, VoltageSecureConfigureGlobal, VoltageSecureProtect, VoltageSecureProtect, VoltageSecureProtectAllKeys, VoltageSecureRefreshPolicy, VoltageSecureVersion, append_centers, apply_bisecting_kmeans, apply_iforest, apply_inverse_pca, apply_inverse_svd, apply_kmeans, apply_kprototypes, apply_normalize, apply_one_hot_encoder, apply_pca, apply_svd, approximate_quantiles, ar_create_blobs, ar_final_newton, ar_save_model, ar_transition_newton, arima_bfgs, arima_line_search, arima_save_model, avg_all_columns_local, bisecting_kmeans_init_model, bk_apply_best_kmeans_results, bk_compute_totss_local, bk_finalize_model, bk_get_rows_in_active_cluster, bk_kmeans_compute_local_centers, bk_kmeans_compute_withinss, bk_kmeans_fast_random_init, bk_kmeans_slow_random_init, bk_kmeanspp_init_cur_cluster, bk_kmeanspp_reset_blob, bk_kmeanspp_select_new_centers, bk_kmeanspp_within_chunk_sum, bk_save_final_model, bk_write_new_cluster_level, blob_to_table, bufUdx, bufUdx, calc_pseudo_centers, calculate_alpha_linear, calculate_hessian_linear1, calculate_hessian_linear2, chi_squared, cleanup_kmeans_files, compute_and_save_global_center, compute_and_save_new_centers, compute_local_totss, compute_local_withinss, compute_new_local_centers, confusion_matrix, coordinate_descent_covariance, corr_matrix, count_rows_in_blob, create_aggregator_blob, error_rate, evaluate_naive_bayes_model, evaluate_reg_model, evaluate_svm_model, export_model_files, finalize_blob_resource_group, get_attr_minmax, get_attr_robust_zscore, get_attr_zscore, get_model_attribute, get_model_summary, get_robust_zscore_median, iforest_create_blobs, iforest_phase0_udf1, iforest_phase0_udf2, iforest_phase1_udf1, iforest_phase1_udf2, iforest_phase1_udf3, iforest_phase1_udf4, iforest_phase2_udf1, iforest_phase2_udf2, iforest_phase2_udf3, iforest_phase2_udf4, iforest_save_model, import_model_files, isOrContains, kmeansAddMetricsToModel, kmeans_init_blobs, kmeans_to_write_final_centers, lift_table, line_search_logistic1, line_search_logistic2, load_rows_into_blocks, map_factor, math_op, matrix_global_xtx, matrix_local_xtx, mode_finder, model_converter, naive_bayes_phase1, naive_bayes_phase1_blob, naive_bayes_phase2, pca_prep1_global, pca_prep1_local, pca_prep2, pmml_parser, predict_arima, predict_autoregressor, predict_linear_reg, predict_logistic_reg, predict_moving_average, predict_naive_bayes, predict_naive_bayes_classes, predict_pmml, predict_poisson_reg, predict_rf_classifier, predict_rf_classifier_classes, predict_rf_regressor, predict_svm_classifier, predict_svm_regressor, predict_xgb_classifier, predict_xgb_classifier_classes, predict_xgb_regressor, random_init, random_init_write, read_from_dfblob, read_map_factor, read_ptree, read_tree, reg_final_bfgs, reg_final_newton, reg_transition_bfgs, reg_transition_newton, reg_write_model, remove_blob, reverse_normalize, rf_blob, rf_clean, rf_phase0_udf1, rf_phase0_udf2, rf_phase1_udf1, rf_phase1_udf2, rf_phase1_udf3, rf_phase1_udf4, rf_phase2_udf1, rf_phase2_udf2, rf_phase2_udf3, rf_phase2_udf4, rf_predictor_importance, rf_save_model, rsquared, save_cv_result, save_pca_model, save_svd_model, save_svm_model, select_new_centers, store_minmax_model, store_one_hot_encoder_model, store_robust_zscore_model, store_zscore_model, table_to_blob, table_to_dfblob, tokenize, topk, update_and_return_sum_of_squared_distances, upgrade_model_format, writeInitialKmeansModelToDfs, xgb_create_blobs, xgb_phase0_udf1, xgb_phase0_udf2, xgb_phase1_udf1, xgb_phase1_udf2, xgb_phase1_udf3, xgb_phase2_udf1, xgb_phase2_udf2, xgb_phase2_udf3, xgb_predictor_importance, xgb_prune, xgb_save_model, yule_walker, ", @@ -6142,7 +6144,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", + "entityUrn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -6158,7 +6160,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", + "entityUrn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -6174,7 +6176,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", + "entityUrn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -6192,12 +6194,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", + "entityUrn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "container": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" } }, "systemMetadata": { @@ -6239,7 +6241,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -6607,12 +6609,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -6656,7 +6658,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -7024,12 +7026,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -7073,7 +7075,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -7324,12 +7326,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -7373,7 +7375,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -7572,12 +7574,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -7621,7 +7623,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -7989,12 +7991,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -8038,7 +8040,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -8367,12 +8369,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -8416,7 +8418,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -8589,12 +8591,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -8638,7 +8640,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -8785,12 +8787,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -8834,7 +8836,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -9007,12 +9009,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -9056,7 +9058,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -9190,12 +9192,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -9239,7 +9241,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -9347,12 +9349,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -9396,7 +9398,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "container": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } }, "systemMetadata": { @@ -9504,12 +9506,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4", - "urn": "urn:li:container:eb682025a9113b5543ec7ed26bfa21e4" + "id": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705", + "urn": "urn:li:container:6f2fa3ed5b7c2d4f7cb8eeaefb9fb705" } ] } @@ -9522,7 +9524,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:342b43fc61f85b16580be55c11e89787", + "entityUrn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -9530,7 +9532,7 @@ "customProperties": { "platform": "vertica", "env": "PROD", - "database": "vmart", + "database": "Vmart", "schema": "store", "projection_count": "3", "udx_list": "", @@ -9547,7 +9549,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:342b43fc61f85b16580be55c11e89787", + "entityUrn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -9563,7 +9565,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:342b43fc61f85b16580be55c11e89787", + "entityUrn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -9579,7 +9581,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:342b43fc61f85b16580be55c11e89787", + "entityUrn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -9597,12 +9599,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:342b43fc61f85b16580be55c11e89787", + "entityUrn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "container": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" } }, "systemMetadata": { @@ -9644,7 +9646,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:342b43fc61f85b16580be55c11e89787" + "container": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44" } }, "systemMetadata": { @@ -9973,12 +9975,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:342b43fc61f85b16580be55c11e89787", - "urn": "urn:li:container:342b43fc61f85b16580be55c11e89787" + "id": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", + "urn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44" } ] } @@ -10022,7 +10024,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:342b43fc61f85b16580be55c11e89787" + "container": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44" } }, "systemMetadata": { @@ -10338,12 +10340,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:342b43fc61f85b16580be55c11e89787", - "urn": "urn:li:container:342b43fc61f85b16580be55c11e89787" + "id": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", + "urn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44" } ] } @@ -10387,7 +10389,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:342b43fc61f85b16580be55c11e89787" + "container": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44" } }, "systemMetadata": { @@ -10729,12 +10731,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:342b43fc61f85b16580be55c11e89787", - "urn": "urn:li:container:342b43fc61f85b16580be55c11e89787" + "id": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44", + "urn": "urn:li:container:2f662cbce881bdbfccbd2c74da9e0e44" } ] } @@ -10747,7 +10749,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", + "entityUrn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", "changeType": "UPSERT", "aspectName": "containerProperties", "aspect": { @@ -10755,7 +10757,7 @@ "customProperties": { "platform": "vertica", "env": "PROD", - "database": "vmart", + "database": "Vmart", "schema": "online_sales", "projection_count": "3", "udx_list": "", @@ -10772,7 +10774,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", + "entityUrn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -10788,7 +10790,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", + "entityUrn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { @@ -10804,7 +10806,7 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", + "entityUrn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", "changeType": "UPSERT", "aspectName": "subTypes", "aspect": { @@ -10822,12 +10824,12 @@ }, { "entityType": "container", - "entityUrn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", + "entityUrn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", "changeType": "UPSERT", "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "container": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" } }, "systemMetadata": { @@ -10869,7 +10871,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:ae8df3182db1bb8b3a612998126beae7" + "container": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557" } }, "systemMetadata": { @@ -11042,12 +11044,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", - "urn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7" + "id": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", + "urn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557" } ] } @@ -11091,7 +11093,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:ae8df3182db1bb8b3a612998126beae7" + "container": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557" } }, "systemMetadata": { @@ -11342,12 +11344,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", - "urn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7" + "id": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", + "urn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557" } ] } @@ -11391,7 +11393,7 @@ "aspectName": "container", "aspect": { "json": { - "container": "urn:li:container:ae8df3182db1bb8b3a612998126beae7" + "container": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557" } }, "systemMetadata": { @@ -11746,12 +11748,12 @@ "json": { "path": [ { - "id": "urn:li:container:343f520ad0fb3259b298736800bb1385", - "urn": "urn:li:container:343f520ad0fb3259b298736800bb1385" + "id": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295", + "urn": "urn:li:container:22a1e700b43e78dd5f8b2603aae8e295" }, { - "id": "urn:li:container:ae8df3182db1bb8b3a612998126beae7", - "urn": "urn:li:container:ae8df3182db1bb8b3a612998126beae7" + "id": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557", + "urn": "urn:li:container:5df74c9464cf21d65e8b02a1977ab557" } ] } From 2946131caaa5451e031eb93c4c9de3be60228643 Mon Sep 17 00:00:00 2001 From: david-leifker <114954101+david-leifker@users.noreply.github.com> Date: Tue, 3 Sep 2024 18:43:10 -0500 Subject: [PATCH 10/34] feat(graphql): Lazy dataLoaders (#11293) --- .../datahub/graphql/GmsGraphQLEngine.java | 12 ++--- .../datahub/graphql/GraphQLEngine.java | 13 +---- .../graphql/LazyDataLoaderRegistry.java | 53 +++++++++++++++++++ .../src/main/resources/application.yaml | 2 + .../openapi/config/SpringWebConfig.java | 12 +++++ 5 files changed, 74 insertions(+), 18 deletions(-) create mode 100644 datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/LazyDataLoaderRegistry.java diff --git a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/GmsGraphQLEngine.java b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/GmsGraphQLEngine.java index b470da3c7c74aa..de77ff9444c6e7 100644 --- a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/GmsGraphQLEngine.java +++ b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/GmsGraphQLEngine.java @@ -724,7 +724,7 @@ public GmsGraphQLEngine(final GmsGraphQLEngineArgs args) { * Returns a {@link Supplier} responsible for creating a new {@link DataLoader} from a {@link * LoadableType}. */ - public Map>> loaderSuppliers( + public static Map>> loaderSuppliers( final Collection> loadableTypes) { return loadableTypes.stream() .collect( @@ -1135,16 +1135,16 @@ private DataFetcher getEntityResolver() { }); } - private DataFetcher getResolver(LoadableType loadableType) { - return getResolver(loadableType, this::getUrnField); + private static DataFetcher getResolver(LoadableType loadableType) { + return getResolver(loadableType, GmsGraphQLEngine::getUrnField); } - private DataFetcher getResolver( + private static DataFetcher getResolver( LoadableType loadableType, Function keyProvider) { return new LoadableTypeResolver<>(loadableType, keyProvider); } - private String getUrnField(DataFetchingEnvironment env) { + private static String getUrnField(DataFetchingEnvironment env) { return env.getArgument(URN_FIELD_NAME); } @@ -3025,7 +3025,7 @@ private void configureTestResultResolvers(final RuntimeWiring.Builder builder) { }))); } - private DataLoader> createDataLoader( + private static DataLoader> createDataLoader( final LoadableType graphType, final QueryContext queryContext) { BatchLoaderContextProvider contextProvider = () -> queryContext; DataLoaderOptions loaderOptions = diff --git a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/GraphQLEngine.java b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/GraphQLEngine.java index dd8eabd3ce06fd..97e282c106a9a2 100644 --- a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/GraphQLEngine.java +++ b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/GraphQLEngine.java @@ -28,7 +28,6 @@ import javax.annotation.Nonnull; import javax.annotation.Nullable; import org.dataloader.DataLoader; -import org.dataloader.DataLoaderRegistry; /** * Simple wrapper around a {@link GraphQL} instance providing APIs for building an engine and @@ -100,7 +99,7 @@ public ExecutionResult execute( /* * Init DataLoaderRegistry - should be created for each request. */ - DataLoaderRegistry register = createDataLoaderRegistry(_dataLoaderSuppliers, context); + LazyDataLoaderRegistry register = new LazyDataLoaderRegistry(context, _dataLoaderSuppliers); /* * Construct execution input @@ -218,14 +217,4 @@ public GraphQLEngine build() { graphQLQueryIntrospectionEnabled); } } - - private DataLoaderRegistry createDataLoaderRegistry( - final Map>> dataLoaderSuppliers, - final QueryContext context) { - final DataLoaderRegistry registry = new DataLoaderRegistry(); - for (String key : dataLoaderSuppliers.keySet()) { - registry.register(key, dataLoaderSuppliers.get(key).apply(context)); - } - return registry; - } } diff --git a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/LazyDataLoaderRegistry.java b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/LazyDataLoaderRegistry.java new file mode 100644 index 00000000000000..1a1d2d5f71f336 --- /dev/null +++ b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/LazyDataLoaderRegistry.java @@ -0,0 +1,53 @@ +package com.linkedin.datahub.graphql; + +import java.util.Map; +import java.util.Set; +import java.util.concurrent.ConcurrentHashMap; +import java.util.function.Function; +import java.util.stream.Collectors; +import java.util.stream.Stream; +import lombok.extern.slf4j.Slf4j; +import org.dataloader.DataLoader; +import org.dataloader.DataLoaderRegistry; + +/** + * The purpose of this class is to avoid loading 42+ dataLoaders when many of the graphql queries do + * not use all of them. + */ +@Slf4j +public class LazyDataLoaderRegistry extends DataLoaderRegistry { + private final QueryContext queryContext; + private final Map>> dataLoaderSuppliers; + + public LazyDataLoaderRegistry( + QueryContext queryContext, + Map>> dataLoaderSuppliers) { + super(); + this.queryContext = queryContext; + this.dataLoaderSuppliers = new ConcurrentHashMap<>(dataLoaderSuppliers); + } + + @Override + public DataLoader getDataLoader(String key) { + return super.computeIfAbsent( + key, + k -> { + Function> supplier = dataLoaderSuppliers.get(key); + if (supplier == null) { + throw new IllegalArgumentException("No DataLoader registered for key: " + key); + } + return supplier.apply(queryContext); + }); + } + + @Override + public Set getKeys() { + return Stream.concat(dataLoaders.keySet().stream(), dataLoaderSuppliers.keySet().stream()) + .collect(Collectors.toSet()); + } + + @Override + public DataLoaderRegistry combine(DataLoaderRegistry registry) { + throw new UnsupportedOperationException(); + } +} diff --git a/metadata-service/configuration/src/main/resources/application.yaml b/metadata-service/configuration/src/main/resources/application.yaml index 3f1c6dd1a3d7d8..37399466c50b0c 100644 --- a/metadata-service/configuration/src/main/resources/application.yaml +++ b/metadata-service/configuration/src/main/resources/application.yaml @@ -72,6 +72,8 @@ datahub: host: ${DATAHUB_GMS_HOST:localhost} port: ${DATAHUB_GMS_PORT:8080} useSSL: ${DATAHUB_GMS_USE_SSL:${GMS_USE_SSL:false}} + async: + request-timeout-ms: ${DATAHUB_GMS_ASYNC_REQUEST_TIMEOUT_MS:55000} # URI instead of above host/port/ssl # Priority is given to the URI setting over separate host/port/useSSL parameters diff --git a/metadata-service/openapi-servlet/src/main/java/io/datahubproject/openapi/config/SpringWebConfig.java b/metadata-service/openapi-servlet/src/main/java/io/datahubproject/openapi/config/SpringWebConfig.java index 61c641e358f090..622cf20af9ff57 100644 --- a/metadata-service/openapi-servlet/src/main/java/io/datahubproject/openapi/config/SpringWebConfig.java +++ b/metadata-service/openapi-servlet/src/main/java/io/datahubproject/openapi/config/SpringWebConfig.java @@ -23,7 +23,9 @@ import java.util.function.Supplier; import java.util.stream.Collectors; import java.util.stream.Stream; +import javax.annotation.Nonnull; import org.springdoc.core.models.GroupedOpenApi; +import org.springframework.beans.factory.annotation.Value; import org.springframework.context.annotation.Bean; import org.springframework.context.annotation.Configuration; import org.springframework.format.FormatterRegistry; @@ -32,6 +34,7 @@ import org.springframework.http.converter.HttpMessageConverter; import org.springframework.http.converter.StringHttpMessageConverter; import org.springframework.http.converter.json.MappingJackson2HttpMessageConverter; +import org.springframework.web.servlet.config.annotation.AsyncSupportConfigurer; import org.springframework.web.servlet.config.annotation.WebMvcConfigurer; @OpenAPIDefinition( @@ -48,6 +51,9 @@ public class SpringWebConfig implements WebMvcConfigurer { private static final Set OPENLINEAGE_PACKAGES = Set.of("io.datahubproject.openapi.openlineage"); + @Value("${datahub.gms.async.request-timeout-ms}") + private long asyncTimeoutMilliseconds; + @Override public void configureMessageConverters(List> messageConverters) { messageConverters.add(new StringHttpMessageConverter()); @@ -158,4 +164,10 @@ private Map concat(Supplier> a, Supplier> b) { (v1, v2) -> v2, LinkedHashMap::new)); } + + @Override + public void configureAsyncSupport(@Nonnull AsyncSupportConfigurer configurer) { + WebMvcConfigurer.super.configureAsyncSupport(configurer); + configurer.setDefaultTimeout(asyncTimeoutMilliseconds); + } } From 08a5956e26ec8134b0bb51e30adafccd5e444d64 Mon Sep 17 00:00:00 2001 From: Mayuri Nehate <33225191+mayurinehate@users.noreply.github.com> Date: Wed, 4 Sep 2024 20:12:35 +0530 Subject: [PATCH 11/34] fix(bigquery): followups on bigquery queries v2 integration (#11291) --- .../ingestion/source/bigquery_v2/bigquery.py | 15 +- .../source/bigquery_v2/bigquery_config.py | 25 ++ .../source/bigquery_v2/bigquery_schema.py | 11 +- .../source/bigquery_v2/bigquery_schema_gen.py | 65 ++-- .../bigquery_v2/bigquery_mcp_golden.json | 334 ++++++++++++++++++ .../integration/bigquery_v2/test_bigquery.py | 150 +++++++- 6 files changed, 560 insertions(+), 40 deletions(-) diff --git a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery.py b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery.py index cbd22b689e0d8b..4ec287b885dea9 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery.py +++ b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery.py @@ -116,7 +116,7 @@ def __init__(self, ctx: PipelineContext, config: BigQueryV2Config): ) self.bigquery_data_dictionary = BigQuerySchemaApi( - report=BigQueryV2Report().schema_api_perf, + report=self.report.schema_api_perf, projects_client=config.get_projects_client(), client=config.get_bigquery_client(), ) @@ -248,11 +248,11 @@ def get_workunits_internal(self) -> Iterable[MetadataWorkUnit]: if not projects: return - if self.config.include_schema_metadata: - for project in projects: - yield from self.bq_schema_extractor.get_project_workunits(project) + for project in projects: + yield from self.bq_schema_extractor.get_project_workunits(project) if self.config.use_queries_v2: + # Always ingest View and Snapshot lineage with schema ingestion self.report.set_ingestion_stage("*", "View and Snapshot Lineage") yield from self.lineage_extractor.get_lineage_workunits_for_views_and_snapshots( @@ -263,6 +263,13 @@ def get_workunits_internal(self) -> Iterable[MetadataWorkUnit]: self.bq_schema_extractor.snapshots_by_ref, ) + # if both usage and lineage are disabled then skip queries extractor piece + if ( + not self.config.include_usage_statistics + and not self.config.include_table_lineage + ): + return + self.report.set_ingestion_stage("*", QUERIES_EXTRACTION) queries_extractor = BigQueryQueriesExtractor( diff --git a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_config.py b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_config.py index cfbefa5bff65ce..2a34fb82c2050c 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_config.py +++ b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_config.py @@ -467,6 +467,7 @@ def have_table_data_read_permission(self) -> bool: default=True, description="Option to enable/disable lineage generation. Is enabled by default.", ) + max_query_duration: timedelta = Field( default=timedelta(minutes=15), description="Correction to pad start_time and end_time with. For handling the case where the read happens within our time range but the query completion event is delayed and happens after the configured end time.", @@ -521,6 +522,30 @@ def have_table_data_read_permission(self) -> bool: " Set to 1 to disable.", ) + # include_view_lineage and include_view_column_lineage are inherited from SQLCommonConfig + # but not used in bigquery so we hide them from docs. + include_view_lineage: bool = Field(default=True, hidden_from_docs=True) + + include_view_column_lineage: bool = Field(default=True, hidden_from_docs=True) + + @root_validator(pre=True) + def set_include_schema_metadata(cls, values: Dict) -> Dict: + # Historically this is used to disable schema ingestion + if ( + "include_tables" in values + and "include_views" in values + and not values["include_tables"] + and not values["include_views"] + ): + values["include_schema_metadata"] = False + values["include_table_snapshots"] = False + logger.info( + "include_tables and include_views are both set to False." + " Disabling schema metadata ingestion for tables, views, and snapshots." + ) + + return values + @root_validator(skip_on_failure=True) def profile_default_settings(cls, values: Dict) -> Dict: # Extra default SQLAlchemy option for better connection pooling and threading. diff --git a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_schema.py b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_schema.py index f248533edec8d7..7c1abe2ce35691 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_schema.py +++ b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_schema.py @@ -2,7 +2,8 @@ from collections import defaultdict from dataclasses import dataclass, field from datetime import datetime, timezone -from typing import Any, Dict, Iterable, Iterator, List, Optional +from functools import lru_cache +from typing import Any, Dict, FrozenSet, Iterable, Iterator, List, Optional from google.api_core import retry from google.cloud import bigquery, datacatalog_v1, resourcemanager_v3 @@ -175,6 +176,7 @@ def _should_retry(exc: BaseException) -> bool: ) return resp.result() + @lru_cache(maxsize=1) def get_projects(self, max_results_per_page: int = 100) -> List[BigqueryProject]: def _should_retry(exc: BaseException) -> bool: logger.debug( @@ -222,7 +224,8 @@ def _should_retry(exc: BaseException) -> bool: return [] return projects - def get_projects_with_labels(self, labels: List[str]) -> List[BigqueryProject]: + @lru_cache(maxsize=1) + def get_projects_with_labels(self, labels: FrozenSet[str]) -> List[BigqueryProject]: with self.report.list_projects_with_labels_timer: try: projects = [] @@ -675,7 +678,9 @@ def query_project_list_from_labels( report: SourceReport, filters: BigQueryFilter, ) -> Iterable[BigqueryProject]: - projects = schema_api.get_projects_with_labels(filters.filter_config.project_labels) + projects = schema_api.get_projects_with_labels( + frozenset(filters.filter_config.project_labels) + ) if not projects: # Report failure on exception and if empty list is returned report.report_failure( diff --git a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_schema_gen.py b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_schema_gen.py index 8bcdc5a4a675d4..29228565d08865 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_schema_gen.py +++ b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/bigquery_schema_gen.py @@ -188,7 +188,11 @@ def __init__( @property def store_table_refs(self): - return self.config.include_table_lineage or self.config.include_usage_statistics + return ( + self.config.include_table_lineage + or self.config.include_usage_statistics + or self.config.use_queries_v2 + ) def get_project_workunits( self, project: BigqueryProject @@ -312,7 +316,8 @@ def _process_project( f"Excluded project '{project_id}' since no datasets were found. {action_message}" ) else: - yield from self.gen_project_id_containers(project_id) + if self.config.include_schema_metadata: + yield from self.gen_project_id_containers(project_id) self.report.warning( title="No datasets found in project", message=action_message, @@ -320,7 +325,8 @@ def _process_project( ) return - yield from self.gen_project_id_containers(project_id) + if self.config.include_schema_metadata: + yield from self.gen_project_id_containers(project_id) self.report.num_project_datasets_to_scan[project_id] = len( bigquery_project.datasets @@ -392,9 +398,10 @@ def _process_schema( ) -> Iterable[MetadataWorkUnit]: dataset_name = bigquery_dataset.name - yield from self.gen_dataset_containers( - dataset_name, project_id, bigquery_dataset.labels - ) + if self.config.include_schema_metadata: + yield from self.gen_dataset_containers( + dataset_name, project_id, bigquery_dataset.labels + ) columns = None @@ -404,11 +411,7 @@ def _process_schema( max_calls=self.config.requests_per_min, period=60 ) - if ( - self.config.include_tables - or self.config.include_views - or self.config.include_table_snapshots - ): + if self.config.include_schema_metadata: columns = self.schema_api.get_columns_for_dataset( project_id=project_id, dataset_name=dataset_name, @@ -418,6 +421,27 @@ def _process_schema( report=self.report, rate_limiter=rate_limiter, ) + elif self.store_table_refs: + # Need table_refs to calculate lineage and usage + for table_item in self.schema_api.list_tables(dataset_name, project_id): + identifier = BigqueryTableIdentifier( + project_id=project_id, + dataset=dataset_name, + table=table_item.table_id, + ) + if not self.config.table_pattern.allowed(identifier.raw_table_name()): + self.report.report_dropped(identifier.raw_table_name()) + continue + try: + self.table_refs.add( + str(BigQueryTableRef(identifier).get_sanitized_table_ref()) + ) + except Exception as e: + logger.warning( + f"Could not create table ref for {table_item.path}: {e}" + ) + yield from [] + return if self.config.include_tables: db_tables[dataset_name] = list( @@ -447,25 +471,6 @@ def _process_schema( ) ), ) - elif self.store_table_refs: - # Need table_refs to calculate lineage and usage - for table_item in self.schema_api.list_tables(dataset_name, project_id): - identifier = BigqueryTableIdentifier( - project_id=project_id, - dataset=dataset_name, - table=table_item.table_id, - ) - if not self.config.table_pattern.allowed(identifier.raw_table_name()): - self.report.report_dropped(identifier.raw_table_name()) - continue - try: - self.table_refs.add( - str(BigQueryTableRef(identifier).get_sanitized_table_ref()) - ) - except Exception as e: - logger.warning( - f"Could not create table ref for {table_item.path}: {e}" - ) if self.config.include_views: db_views[dataset_name] = list( diff --git a/metadata-ingestion/tests/integration/bigquery_v2/bigquery_mcp_golden.json b/metadata-ingestion/tests/integration/bigquery_v2/bigquery_mcp_golden.json index bcbdd02506f734..bc9d734218903d 100644 --- a/metadata-ingestion/tests/integration/bigquery_v2/bigquery_mcp_golden.json +++ b/metadata-ingestion/tests/integration/bigquery_v2/bigquery_mcp_golden.json @@ -401,6 +401,129 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.view-1,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.view-1,PROD)", + "changeType": "UPSERT", + "aspectName": "schemaMetadata", + "aspect": { + "json": { + "schemaName": "project-id-1.bigquery-dataset-1.view-1", + "platform": "urn:li:dataPlatform:bigquery", + "version": 0, + "created": { + "time": 0, + "actor": "urn:li:corpuser:unknown" + }, + "lastModified": { + "time": 0, + "actor": "urn:li:corpuser:unknown" + }, + "hash": "", + "platformSchema": { + "com.linkedin.schema.MySqlDDL": { + "tableSchema": "" + } + }, + "fields": [ + { + "fieldPath": "age", + "nullable": false, + "description": "comment", + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "nativeDataType": "INT", + "recursive": false, + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Test Policy Tag" + } + ] + }, + "isPartOfKey": false + }, + { + "fieldPath": "email", + "nullable": false, + "description": "comment", + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "nativeDataType": "STRING", + "recursive": false, + "globalTags": { + "tags": [] + }, + "isPartOfKey": false + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.view-1,PROD)", + "changeType": "UPSERT", + "aspectName": "datasetProperties", + "aspect": { + "json": { + "customProperties": {}, + "externalUrl": "https://console.cloud.google.com/bigquery?project=project-id-1&ws=!1m5!1m4!4m3!1sproject-id-1!2sbigquery-dataset-1!3sview-1", + "name": "view-1", + "qualifiedName": "project-id-1.bigquery-dataset-1.view-1", + "description": "", + "tags": [] + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.view-1,PROD)", + "changeType": "UPSERT", + "aspectName": "container", + "aspect": { + "json": { + "container": "urn:li:container:8df46c5e3ded05a3122b0015822c0ef0" + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "dataset", "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.snapshot-table-1,PROD)", @@ -433,6 +556,24 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.view-1,PROD)", + "changeType": "UPSERT", + "aspectName": "subTypes", + "aspect": { + "json": { + "typeNames": [ + "View" + ] + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "dataset", "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.snapshot-table-1,PROD)", @@ -524,6 +665,66 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.view-1,PROD)", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery", + "instance": "urn:li:dataPlatformInstance:(urn:li:dataPlatform:bigquery,project-id-1)" + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.view-1,PROD)", + "changeType": "UPSERT", + "aspectName": "viewProperties", + "aspect": { + "json": { + "materialized": false, + "viewLogic": "create view `bigquery-dataset-1.view-1` as select email from `bigquery-dataset-1.table-1`", + "viewLanguage": "SQL" + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.view-1,PROD)", + "changeType": "UPSERT", + "aspectName": "browsePathsV2", + "aspect": { + "json": { + "path": [ + { + "id": "urn:li:container:068bd9323110994a40019fcf6cfc60d3", + "urn": "urn:li:container:068bd9323110994a40019fcf6cfc60d3" + }, + { + "id": "urn:li:container:8df46c5e3ded05a3122b0015822c0ef0", + "urn": "urn:li:container:8df46c5e3ded05a3122b0015822c0ef0" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "glossaryTerm", "entityUrn": "urn:li:glossaryTerm:Email_Address", @@ -607,6 +808,34 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:view_urn%3Ali%3Adataset%3A%28urn%3Ali%3AdataPlatform%3Abigquery%2Cproject-id-1.bigquery-dataset-1.view-1%2CPROD%29", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "CREATE VIEW `bigquery-dataset-1.view-1` AS\nSELECT\n email\nFROM `bigquery-dataset-1.table-1`", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 0, + "actor": "urn:li:corpuser:_ingestion" + }, + "lastModified": { + "time": 1643871600000, + "actor": "urn:li:corpuser:_ingestion" + } + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "dataset", "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.snapshot-table-1,PROD)", @@ -632,6 +861,35 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:view_urn%3Ali%3Adataset%3A%28urn%3Ali%3AdataPlatform%3Abigquery%2Cproject-id-1.bigquery-dataset-1.view-1%2CPROD%29", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.table-1,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.table-1,PROD),email)" + }, + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.view-1,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.view-1,PROD),email)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "dataset", "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.snapshot-table-1,PROD)", @@ -684,5 +942,81 @@ "runId": "bigquery-2022_02_03-07_00_00", "lastRunId": "no-run-id-provided" } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:view_urn%3Ali%3Adataset%3A%28urn%3Ali%3AdataPlatform%3Abigquery%2Cproject-id-1.bigquery-dataset-1.view-1%2CPROD%29", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:view_urn%3Ali%3Adataset%3A%28urn%3Ali%3AdataPlatform%3Abigquery%2Cproject-id-1.bigquery-dataset-1.view-1%2CPROD%29", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.view-1,PROD)", + "changeType": "UPSERT", + "aspectName": "upstreamLineage", + "aspect": { + "json": { + "upstreams": [ + { + "auditStamp": { + "time": 1643871600000, + "actor": "urn:li:corpuser:_ingestion" + }, + "created": { + "time": 0, + "actor": "urn:li:corpuser:_ingestion" + }, + "dataset": "urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.table-1,PROD)", + "type": "VIEW", + "query": "urn:li:query:view_urn%3Ali%3Adataset%3A%28urn%3Ali%3AdataPlatform%3Abigquery%2Cproject-id-1.bigquery-dataset-1.view-1%2CPROD%29" + } + ], + "fineGrainedLineages": [ + { + "upstreamType": "FIELD_SET", + "upstreams": [ + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.table-1,PROD),email)" + ], + "downstreamType": "FIELD", + "downstreams": [ + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,project-id-1.bigquery-dataset-1.view-1,PROD),email)" + ], + "confidenceScore": 0.9, + "query": "urn:li:query:view_urn%3Ali%3Adataset%3A%28urn%3Ali%3AdataPlatform%3Abigquery%2Cproject-id-1.bigquery-dataset-1.view-1%2CPROD%29" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1643871600000, + "runId": "bigquery-2022_02_03-07_00_00", + "lastRunId": "no-run-id-provided" + } } ] \ No newline at end of file diff --git a/metadata-ingestion/tests/integration/bigquery_v2/test_bigquery.py b/metadata-ingestion/tests/integration/bigquery_v2/test_bigquery.py index 36199ee0e26000..9029182bb14a32 100644 --- a/metadata-ingestion/tests/integration/bigquery_v2/test_bigquery.py +++ b/metadata-ingestion/tests/integration/bigquery_v2/test_bigquery.py @@ -20,6 +20,7 @@ BigQuerySchemaApi, BigqueryTable, BigqueryTableSnapshot, + BigqueryView, ) from datahub.ingestion.source.bigquery_v2.bigquery_schema_gen import ( BigQuerySchemaGenerator, @@ -63,6 +64,7 @@ def recipe(mcp_output_path: str, override: dict = {}) -> dict: ], max_workers=1, ).dict(), + **override, }, }, "sink": {"type": "file", "config": {"filename": mcp_output_path}}, @@ -71,6 +73,7 @@ def recipe(mcp_output_path: str, override: dict = {}) -> dict: @freeze_time(FROZEN_TIME) @patch.object(BigQuerySchemaApi, "get_snapshots_for_dataset") +@patch.object(BigQuerySchemaApi, "get_views_for_dataset") @patch.object(BigQuerySchemaApi, "get_tables_for_dataset") @patch.object(BigQuerySchemaGenerator, "get_core_table_details") @patch.object(BigQuerySchemaApi, "get_datasets_for_project_id") @@ -88,6 +91,7 @@ def test_bigquery_v2_ingest( get_datasets_for_project_id, get_core_table_details, get_tables_for_dataset, + get_views_for_dataset, get_snapshots_for_dataset, pytestconfig, tmp_path, @@ -96,15 +100,15 @@ def test_bigquery_v2_ingest( mcp_golden_path = f"{test_resources_dir}/bigquery_mcp_golden.json" mcp_output_path = "{}/{}".format(tmp_path, "bigquery_mcp_output.json") - get_datasets_for_project_id.return_value = [ - BigqueryDataset(name="bigquery-dataset-1") - ] + dataset_name = "bigquery-dataset-1" + get_datasets_for_project_id.return_value = [BigqueryDataset(name=dataset_name)] table_list_item = TableListItem( {"tableReference": {"projectId": "", "datasetId": "", "tableId": ""}} ) table_name = "table-1" snapshot_table_name = "snapshot-table-1" + view_name = "view-1" get_core_table_details.return_value = {table_name: table_list_item} columns = [ BigqueryColumn( @@ -133,6 +137,7 @@ def test_bigquery_v2_ingest( get_columns_for_dataset.return_value = { table_name: columns, snapshot_table_name: columns, + view_name: columns, } get_sample_data_for_table.return_value = { "age": [random.randint(1, 80) for i in range(20)], @@ -163,6 +168,19 @@ def test_bigquery_v2_ingest( ) get_snapshots_for_dataset.return_value = iter([snapshot_table]) + bigquery_view = BigqueryView( + name=view_name, + comment=None, + created=None, + view_definition=f"create view `{dataset_name}.view-1` as select email from `{dataset_name}.table-1`", + last_altered=None, + size_in_bytes=None, + rows_count=None, + materialized=False, + ) + + get_views_for_dataset.return_value = iter([bigquery_view]) + pipeline_config_dict: Dict[str, Any] = recipe(mcp_output_path=mcp_output_path) run_and_get_pipeline(pipeline_config_dict) @@ -269,3 +287,129 @@ def test_bigquery_v2_project_labels_ingest( output_path=mcp_output_path, golden_path=mcp_golden_path, ) + + +@freeze_time(FROZEN_TIME) +@patch.object(BigQuerySchemaApi, "get_snapshots_for_dataset") +@patch.object(BigQuerySchemaApi, "get_views_for_dataset") +@patch.object(BigQuerySchemaApi, "get_tables_for_dataset") +@patch.object(BigQuerySchemaGenerator, "get_core_table_details") +@patch.object(BigQuerySchemaApi, "get_datasets_for_project_id") +@patch.object(BigQuerySchemaApi, "get_columns_for_dataset") +@patch.object(BigQueryDataReader, "get_sample_data_for_table") +@patch("google.cloud.bigquery.Client") +@patch("google.cloud.datacatalog_v1.PolicyTagManagerClient") +@patch("google.cloud.resourcemanager_v3.ProjectsClient") +def test_bigquery_queries_v2_ingest( + client, + policy_tag_manager_client, + projects_client, + get_sample_data_for_table, + get_columns_for_dataset, + get_datasets_for_project_id, + get_core_table_details, + get_tables_for_dataset, + get_views_for_dataset, + get_snapshots_for_dataset, + pytestconfig, + tmp_path, +): + test_resources_dir = pytestconfig.rootpath / "tests/integration/bigquery_v2" + mcp_golden_path = f"{test_resources_dir}/bigquery_mcp_golden.json" + mcp_output_path = "{}/{}".format(tmp_path, "bigquery_mcp_output.json") + + dataset_name = "bigquery-dataset-1" + get_datasets_for_project_id.return_value = [BigqueryDataset(name=dataset_name)] + + table_list_item = TableListItem( + {"tableReference": {"projectId": "", "datasetId": "", "tableId": ""}} + ) + table_name = "table-1" + snapshot_table_name = "snapshot-table-1" + view_name = "view-1" + get_core_table_details.return_value = {table_name: table_list_item} + columns = [ + BigqueryColumn( + name="age", + ordinal_position=1, + is_nullable=False, + field_path="col_1", + data_type="INT", + comment="comment", + is_partition_column=False, + cluster_column_position=None, + policy_tags=["Test Policy Tag"], + ), + BigqueryColumn( + name="email", + ordinal_position=1, + is_nullable=False, + field_path="col_2", + data_type="STRING", + comment="comment", + is_partition_column=False, + cluster_column_position=None, + ), + ] + + get_columns_for_dataset.return_value = { + table_name: columns, + snapshot_table_name: columns, + view_name: columns, + } + get_sample_data_for_table.return_value = { + "age": [random.randint(1, 80) for i in range(20)], + "email": [random_email() for i in range(20)], + } + + bigquery_table = BigqueryTable( + name=table_name, + comment=None, + created=None, + last_altered=None, + size_in_bytes=None, + rows_count=None, + ) + get_tables_for_dataset.return_value = iter([bigquery_table]) + + bigquery_view = BigqueryView( + name=view_name, + comment=None, + created=None, + view_definition=f"create view `{dataset_name}.view-1` as select email from `{dataset_name}.table-1`", + last_altered=None, + size_in_bytes=None, + rows_count=None, + materialized=False, + ) + + get_views_for_dataset.return_value = iter([bigquery_view]) + snapshot_table = BigqueryTableSnapshot( + name=snapshot_table_name, + comment=None, + created=None, + last_altered=None, + size_in_bytes=None, + rows_count=None, + base_table_identifier=BigqueryTableIdentifier( + project_id="project-id-1", + dataset="bigquery-dataset-1", + table="table-1", + ), + ) + get_snapshots_for_dataset.return_value = iter([snapshot_table]) + + # Even if `include_table_lineage` is disabled, we still ingest view and snapshot lineage + # if use_queries_v2 is set. + pipeline_config_dict: Dict[str, Any] = recipe( + mcp_output_path=mcp_output_path, + override={"use_queries_v2": True, "include_table_lineage": False}, + ) + + run_and_get_pipeline(pipeline_config_dict) + + mce_helpers.check_golden_file( + pytestconfig, + output_path=mcp_output_path, + golden_path=mcp_golden_path, + ) From 401b7874279597d55240421a5483dddc1e0a4c4f Mon Sep 17 00:00:00 2001 From: Harshal Sheth Date: Wed, 4 Sep 2024 08:09:36 -0700 Subject: [PATCH 12/34] fix(ingest): add custom StrEnum type (#11270) --- .../entities/assertion/compiler_interface.py | 6 +--- .../dataprocess/dataprocess_instance.py | 4 +-- .../configuration/time_window_config.py | 3 +- .../ingestion/glossary/datahub_classifier.py | 4 +-- .../src/datahub/ingestion/graph/client.py | 6 ++-- .../ingestion/source/common/subtypes.py | 12 +++---- .../src/datahub/ingestion/source/kafka.py | 4 +-- .../source/looker/looker_query_model.py | 6 +--- .../ingestion/source/snowflake/constants.py | 8 ++--- .../source/snowflake/snowflake_config.py | 4 +-- .../ingestion/source/sql/hive_metastore.py | 5 ++- .../src/datahub/testing/check_str_enum.py | 33 +++++++++++++++++++ .../src/datahub/utilities/str_enum.py | 14 ++++++++ .../tests/performance/data_model.py | 5 +-- .../tests/unit/test_packages.py | 7 ++++ 15 files changed, 83 insertions(+), 38 deletions(-) create mode 100644 metadata-ingestion/src/datahub/testing/check_str_enum.py create mode 100644 metadata-ingestion/src/datahub/utilities/str_enum.py diff --git a/metadata-ingestion/src/datahub/api/entities/assertion/compiler_interface.py b/metadata-ingestion/src/datahub/api/entities/assertion/compiler_interface.py index 27b43a58530b1e..09a2371329c723 100644 --- a/metadata-ingestion/src/datahub/api/entities/assertion/compiler_interface.py +++ b/metadata-ingestion/src/datahub/api/entities/assertion/compiler_interface.py @@ -1,16 +1,12 @@ from abc import abstractmethod from dataclasses import dataclass, field -from enum import Enum from pathlib import Path from typing import Dict, List, Literal from datahub.api.entities.assertion.assertion_config_spec import AssertionsConfigSpec from datahub.ingestion.api.report import Report from datahub.utilities.lossy_collections import LossyDict, LossyList - - -class StrEnum(str, Enum): - pass +from datahub.utilities.str_enum import StrEnum class CompileResultArtifactType(StrEnum): diff --git a/metadata-ingestion/src/datahub/api/entities/dataprocess/dataprocess_instance.py b/metadata-ingestion/src/datahub/api/entities/dataprocess/dataprocess_instance.py index 771efd1f2aa51f..bf521ded5dbf3b 100644 --- a/metadata-ingestion/src/datahub/api/entities/dataprocess/dataprocess_instance.py +++ b/metadata-ingestion/src/datahub/api/entities/dataprocess/dataprocess_instance.py @@ -1,6 +1,5 @@ import time from dataclasses import dataclass, field -from enum import Enum from typing import Callable, Dict, Iterable, List, Optional, Union, cast from datahub.api.entities.datajob import DataFlow, DataJob @@ -21,6 +20,7 @@ DataProcessRunStatusClass, DataProcessTypeClass, ) +from datahub.utilities.str_enum import StrEnum from datahub.utilities.urns.data_flow_urn import DataFlowUrn from datahub.utilities.urns.data_job_urn import DataJobUrn from datahub.utilities.urns.data_process_instance_urn import DataProcessInstanceUrn @@ -33,7 +33,7 @@ class DataProcessInstanceKey(DatahubKey): id: str -class InstanceRunResult(str, Enum): +class InstanceRunResult(StrEnum): SUCCESS = RunResultType.SUCCESS SKIPPED = RunResultType.SKIPPED FAILURE = RunResultType.FAILURE diff --git a/metadata-ingestion/src/datahub/configuration/time_window_config.py b/metadata-ingestion/src/datahub/configuration/time_window_config.py index f20ab85be05855..b3cc0316091173 100644 --- a/metadata-ingestion/src/datahub/configuration/time_window_config.py +++ b/metadata-ingestion/src/datahub/configuration/time_window_config.py @@ -9,10 +9,11 @@ from datahub.configuration.common import ConfigModel from datahub.configuration.datetimes import parse_absolute_time, parse_relative_timespan from datahub.metadata.schema_classes import CalendarIntervalClass +from datahub.utilities.str_enum import StrEnum @enum.unique -class BucketDuration(str, enum.Enum): +class BucketDuration(StrEnum): DAY = CalendarIntervalClass.DAY HOUR = CalendarIntervalClass.HOUR diff --git a/metadata-ingestion/src/datahub/ingestion/glossary/datahub_classifier.py b/metadata-ingestion/src/datahub/ingestion/glossary/datahub_classifier.py index 94a65d887efbc7..50268768d0ce9f 100644 --- a/metadata-ingestion/src/datahub/ingestion/glossary/datahub_classifier.py +++ b/metadata-ingestion/src/datahub/ingestion/glossary/datahub_classifier.py @@ -1,4 +1,3 @@ -from enum import Enum from typing import Any, Dict, List, Optional from datahub_classify.helper_classes import ColumnInfo @@ -10,6 +9,7 @@ from datahub.configuration.common import ConfigModel from datahub.configuration.pydantic_migration_helpers import PYDANTIC_VERSION_2 from datahub.ingestion.glossary.classifier import Classifier +from datahub.utilities.str_enum import StrEnum class NameFactorConfig(ConfigModel): @@ -33,7 +33,7 @@ class DataTypeFactorConfig(ConfigModel): ) -class ValuePredictionType(str, Enum): +class ValuePredictionType(StrEnum): REGEX = "regex" LIBRARY = "library" diff --git a/metadata-ingestion/src/datahub/ingestion/graph/client.py b/metadata-ingestion/src/datahub/ingestion/graph/client.py index 55bd0b3cf0afc1..234d7e5e255d74 100644 --- a/metadata-ingestion/src/datahub/ingestion/graph/client.py +++ b/metadata-ingestion/src/datahub/ingestion/graph/client.py @@ -1,5 +1,4 @@ import contextlib -import enum import functools import json import logging @@ -67,6 +66,7 @@ TelemetryClientIdClass, ) from datahub.utilities.perf_timer import PerfTimer +from datahub.utilities.str_enum import StrEnum from datahub.utilities.urns.urn import Urn, guess_entity_type if TYPE_CHECKING: @@ -1138,9 +1138,7 @@ def execute_graphql( return result["data"] - class RelationshipDirection(str, enum.Enum): - # FIXME: Upgrade to enum.StrEnum when we drop support for Python 3.10 - + class RelationshipDirection(StrEnum): INCOMING = "INCOMING" OUTGOING = "OUTGOING" diff --git a/metadata-ingestion/src/datahub/ingestion/source/common/subtypes.py b/metadata-ingestion/src/datahub/ingestion/source/common/subtypes.py index 4d335779fe49b0..fb22f0b6edde26 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/common/subtypes.py +++ b/metadata-ingestion/src/datahub/ingestion/source/common/subtypes.py @@ -1,7 +1,7 @@ -from enum import Enum +from datahub.utilities.str_enum import StrEnum -class DatasetSubTypes(str, Enum): +class DatasetSubTypes(StrEnum): # Generic SubTypes TABLE = "Table" VIEW = "View" @@ -26,7 +26,7 @@ class DatasetSubTypes(str, Enum): NOTEBOOK = "Notebook" -class DatasetContainerSubTypes(str, Enum): +class DatasetContainerSubTypes(StrEnum): # Generic SubTypes DATABASE = "Database" SCHEMA = "Schema" @@ -41,7 +41,7 @@ class DatasetContainerSubTypes(str, Enum): ABS_CONTAINER = "ABS container" -class BIContainerSubTypes(str, Enum): +class BIContainerSubTypes(StrEnum): LOOKER_FOLDER = "Folder" LOOKML_PROJECT = "LookML Project" LOOKML_MODEL = "LookML Model" @@ -55,11 +55,11 @@ class BIContainerSubTypes(str, Enum): MODE_COLLECTION = "Collection" -class JobContainerSubTypes(str, Enum): +class JobContainerSubTypes(StrEnum): NIFI_PROCESS_GROUP = "Process Group" -class BIAssetSubTypes(str, Enum): +class BIAssetSubTypes(StrEnum): # Generic SubTypes REPORT = "Report" diff --git a/metadata-ingestion/src/datahub/ingestion/source/kafka.py b/metadata-ingestion/src/datahub/ingestion/source/kafka.py index 0d718e509d5c58..a757250a0d6c85 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/kafka.py +++ b/metadata-ingestion/src/datahub/ingestion/source/kafka.py @@ -2,7 +2,6 @@ import json import logging from dataclasses import dataclass, field -from enum import Enum from typing import Any, Dict, Iterable, List, Optional, Type, cast import avro.schema @@ -73,11 +72,12 @@ ) from datahub.utilities.mapping import Constants, OperationProcessor from datahub.utilities.registries.domain_registry import DomainRegistry +from datahub.utilities.str_enum import StrEnum logger = logging.getLogger(__name__) -class KafkaTopicConfigKeys(str, Enum): +class KafkaTopicConfigKeys(StrEnum): MIN_INSYNC_REPLICAS_CONFIG = "min.insync.replicas" RETENTION_SIZE_CONFIG = "retention.bytes" RETENTION_TIME_CONFIG = "retention.ms" diff --git a/metadata-ingestion/src/datahub/ingestion/source/looker/looker_query_model.py b/metadata-ingestion/src/datahub/ingestion/source/looker/looker_query_model.py index b3002828ceefff..7ed46c8f7084cf 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/looker/looker_query_model.py +++ b/metadata-ingestion/src/datahub/ingestion/source/looker/looker_query_model.py @@ -1,13 +1,9 @@ from dataclasses import dataclass, field -from enum import Enum from typing import Dict, List, cast from looker_sdk.sdk.api40.models import WriteQuery - -# Enum whose value is string and compatible with dictionary having string value as key -class StrEnum(str, Enum): - pass +from datahub.utilities.str_enum import StrEnum class LookerModel(StrEnum): diff --git a/metadata-ingestion/src/datahub/ingestion/source/snowflake/constants.py b/metadata-ingestion/src/datahub/ingestion/source/snowflake/constants.py index 3ce684b29cf396..fc464cc5ea9bb5 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/snowflake/constants.py +++ b/metadata-ingestion/src/datahub/ingestion/source/snowflake/constants.py @@ -1,7 +1,7 @@ -from enum import Enum +from datahub.utilities.str_enum import StrEnum -class SnowflakeCloudProvider(str, Enum): +class SnowflakeCloudProvider(StrEnum): AWS = "aws" GCP = "gcp" AZURE = "azure" @@ -10,7 +10,7 @@ class SnowflakeCloudProvider(str, Enum): SNOWFLAKE_DEFAULT_CLOUD = SnowflakeCloudProvider.AWS -class SnowflakeEdition(str, Enum): +class SnowflakeEdition(StrEnum): STANDARD = "Standard" # We use this to represent Enterprise Edition or higher @@ -44,7 +44,7 @@ class SnowflakeEdition(str, Enum): # We will always compare with lowercase # Complete list for objectDomain - https://docs.snowflake.com/en/sql-reference/account-usage/access_history.html -class SnowflakeObjectDomain(str, Enum): +class SnowflakeObjectDomain(StrEnum): TABLE = "table" EXTERNAL_TABLE = "external table" VIEW = "view" diff --git a/metadata-ingestion/src/datahub/ingestion/source/snowflake/snowflake_config.py b/metadata-ingestion/src/datahub/ingestion/source/snowflake/snowflake_config.py index 9e74fb8b496aa2..229c0e292fbafe 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/snowflake/snowflake_config.py +++ b/metadata-ingestion/src/datahub/ingestion/source/snowflake/snowflake_config.py @@ -1,7 +1,6 @@ import logging from collections import defaultdict from dataclasses import dataclass -from enum import Enum from typing import Dict, List, Optional, Set, cast import pydantic @@ -31,6 +30,7 @@ ) from datahub.ingestion.source.usage.usage_common import BaseUsageConfig from datahub.utilities.global_warning_util import add_global_warning +from datahub.utilities.str_enum import StrEnum logger = logging.Logger(__name__) @@ -48,7 +48,7 @@ ] -class TagOption(str, Enum): +class TagOption(StrEnum): with_lineage = "with_lineage" without_lineage = "without_lineage" skip = "skip" diff --git a/metadata-ingestion/src/datahub/ingestion/source/sql/hive_metastore.py b/metadata-ingestion/src/datahub/ingestion/source/sql/hive_metastore.py index 9da6c294881247..adb171d4ad54b6 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/sql/hive_metastore.py +++ b/metadata-ingestion/src/datahub/ingestion/source/sql/hive_metastore.py @@ -2,7 +2,6 @@ import json import logging from collections import namedtuple -from enum import Enum from itertools import groupby from typing import Any, Dict, Iterable, List, Optional, Tuple, Union @@ -10,7 +9,6 @@ from pydantic.fields import Field # This import verifies that the dependencies are available. -from pyhive import hive # noqa: F401 from sqlalchemy import create_engine, text from sqlalchemy.engine.reflection import Inspector @@ -61,13 +59,14 @@ ViewPropertiesClass, ) from datahub.utilities.hive_schema_to_avro import get_schema_fields_for_hive_column +from datahub.utilities.str_enum import StrEnum logger: logging.Logger = logging.getLogger(__name__) TableKey = namedtuple("TableKey", ["schema", "table"]) -class HiveMetastoreConfigMode(str, Enum): +class HiveMetastoreConfigMode(StrEnum): hive: str = "hive" # noqa: F811 presto: str = "presto" presto_on_hive: str = "presto-on-hive" diff --git a/metadata-ingestion/src/datahub/testing/check_str_enum.py b/metadata-ingestion/src/datahub/testing/check_str_enum.py new file mode 100644 index 00000000000000..2d1a84aa5f738d --- /dev/null +++ b/metadata-ingestion/src/datahub/testing/check_str_enum.py @@ -0,0 +1,33 @@ +import pathlib +from typing import List + + +def ensure_no_enum_mixin(dirs: List[pathlib.Path]) -> None: + # See the docs on the StrEnum implementation for why this is necessary. + + bad_lines = { + "(str, Enum)", + "(str, enum.Enum)", + # We don't have any int enums right now, but this will catch them if we add some. + "(int, Enum)", + "(int, enum.Enum)", + } + + ignored_files = { + "datahub/utilities/str_enum.py", + "datahub/testing/check_str_enum.py", + } + + for dir in dirs: + for file in dir.rglob("*.py"): + if any(str(file).endswith(ignored_file) for ignored_file in ignored_files): + continue + + with file.open() as f: + for line in f: + if any(bad_line in line for bad_line in bad_lines): + raise ValueError( + f"Disallowed enum mixin found in {file}: `{line.rstrip()}`. " + "This enum mixin's behavior changed in Python 3.11, so it will work inconsistently across versions." + "Use datahub.utilities.str_enum.StrEnum instead." + ) diff --git a/metadata-ingestion/src/datahub/utilities/str_enum.py b/metadata-ingestion/src/datahub/utilities/str_enum.py new file mode 100644 index 00000000000000..b8392f40770e4a --- /dev/null +++ b/metadata-ingestion/src/datahub/utilities/str_enum.py @@ -0,0 +1,14 @@ +from enum import Enum + + +class StrEnum(str, Enum): + """String Enum class.""" + + # This is required for compatibility with Python 3.11+, which changed the + # behavior of enums in format() and f-strings. + # Once we're using only Python 3.11+, we can replace this with enum.StrEnum. + # See https://blog.pecar.me/python-enum for more details. + + def __str__(self) -> str: + """Return the string representation of the enum.""" + return str(self.value) diff --git a/metadata-ingestion/tests/performance/data_model.py b/metadata-ingestion/tests/performance/data_model.py index 728bb6ddde2157..99b8820b45fba9 100644 --- a/metadata-ingestion/tests/performance/data_model.py +++ b/metadata-ingestion/tests/performance/data_model.py @@ -2,11 +2,12 @@ from collections import OrderedDict from dataclasses import dataclass, field from datetime import datetime -from enum import Enum from typing import Dict, List, Optional, Union from typing_extensions import Literal +from datahub.utilities.str_enum import StrEnum + StatementType = Literal[ # SELECT + values from OperationTypeClass "SELECT", "INSERT", @@ -26,7 +27,7 @@ class Container: parent: Optional["Container"] = None -class ColumnType(str, Enum): +class ColumnType(StrEnum): # Can add types that take parameters in the future INTEGER = "INTEGER" diff --git a/metadata-ingestion/tests/unit/test_packages.py b/metadata-ingestion/tests/unit/test_packages.py index 69fe42e9f1e8a2..f4045bac6e6ef4 100644 --- a/metadata-ingestion/tests/unit/test_packages.py +++ b/metadata-ingestion/tests/unit/test_packages.py @@ -2,6 +2,7 @@ import setuptools from datahub.testing.check_imports import ensure_no_indirect_model_imports +from datahub.testing.check_str_enum import ensure_no_enum_mixin def test_package_list_match_inits(): @@ -15,3 +16,9 @@ def test_check_import_paths(pytestconfig: pytest.Config) -> None: root = pytestconfig.rootpath ensure_no_indirect_model_imports([root / "src", root / "tests"]) + + +def test_check_str_enum_usage(pytestconfig: pytest.Config) -> None: + root = pytestconfig.rootpath + + ensure_no_enum_mixin([root / "src", root / "tests"]) From ede9520b878e6e1d93d5457261c0445348467593 Mon Sep 17 00:00:00 2001 From: david-leifker <114954101+david-leifker@users.noreply.github.com> Date: Wed, 4 Sep 2024 15:36:12 -0500 Subject: [PATCH 13/34] feat(schemaField): populate schemaFields with side effects (#10928) --- .github/workflows/docker-unified.yml | 7 + .../datahub/graphql/QueryContext.java | 3 + .../graphql/resolvers/ResolverUtils.java | 23 - .../UpsertCustomAssertionResolver.java | 2 +- .../ListDataProductAssetsResolver.java | 101 +- .../resolvers/post/CreatePostResolver.java | 22 +- .../dataset/mappers/SchemaFieldMapper.java | 3 +- .../graphql/types/mappers/MapperUtils.java | 21 +- .../src/main/resources/entity.graphql | 15 + .../src/main/resources/search.graphql | 17 + .../graphql/resolvers/ResolverUtilsTest.java | 16 +- .../datacontract/DataContractUtilsTest.java | 6 + .../post/CreatePostResolverTest.java | 2 +- datahub-upgrade/build.gradle | 5 +- .../com/linkedin/datahub/upgrade/Upgrade.java | 24 + .../linkedin/datahub/upgrade/UpgradeCli.java | 3 +- .../datahub/upgrade/UpgradeContext.java | 2 +- .../datahub/upgrade/UpgradeResult.java | 16 +- .../datahub/upgrade/UpgradeStepResult.java | 12 +- .../common/steps/ClearGraphServiceStep.java | 5 +- .../common/steps/ClearSearchServiceStep.java | 5 +- .../steps/ClearSystemMetadataServiceStep.java | 5 +- .../common/steps/GMSDisableWriteModeStep.java | 5 +- .../common/steps/GMSEnableWriteModeStep.java | 5 +- .../common/steps/GMSQualificationStep.java | 7 +- .../upgrade/config/SchemaFieldsConfig.java | 56 + .../upgrade/config/SystemUpdateConfig.java | 56 + .../upgrade/impl/DefaultUpgradeManager.java | 15 +- .../upgrade/impl/DefaultUpgradeResult.java | 7 +- .../impl/DefaultUpgradeStepResult.java | 9 +- .../upgrade/nocode/CreateAspectTableStep.java | 5 +- .../upgrade/nocode/DataMigrationStep.java | 13 +- .../nocode/RemoveAspectV2TableStep.java | 3 +- .../nocode/UpgradeQualificationStep.java | 9 +- .../nocodecleanup/DeleteAspectTableStep.java | 5 +- .../DeleteLegacyGraphRelationshipsStep.java | 5 +- .../DeleteLegacySearchIndicesStep.java | 5 +- .../NoCodeUpgradeQualificationStep.java | 7 +- .../RemoveClientIdAspectStep.java | 4 +- .../restorebackup/ClearAspectV2TableStep.java | 3 +- .../restorebackup/RestoreStorageStep.java | 5 +- .../upgrade/restoreindices/SendMAEStep.java | 5 +- .../upgrade/system/AbstractMCLStep.java | 3 +- .../BackfillBrowsePathsV2Step.java | 3 +- .../steps/BuildIndicesPostStep.java | 7 +- .../steps/BuildIndicesPreStep.java | 9 +- .../elasticsearch/steps/BuildIndicesStep.java | 5 +- .../elasticsearch/steps/CleanIndicesStep.java | 5 +- .../steps/DataHubStartupStep.java | 5 +- .../BackfillPolicyFieldsStep.java | 3 +- ...enerateSchemaFieldsFromSchemaMetadata.java | 48 + ...ateSchemaFieldsFromSchemaMetadataStep.java | 256 + .../schemafield/MigrateSchemaFieldDocIds.java | 50 + .../MigrateSchemaFieldDocIdsStep.java | 291 + .../DatahubUpgradeNoSchemaRegistryTest.java | 3 +- ...chemaFieldsFromSchemaMetadataStepTest.java | 110 + .../metadata/aspect/batch/AspectsBatch.java | 1 + .../metadata/aspect/batch/MCLItem.java | 9 + .../java/com/linkedin/metadata/Constants.java | 3 + .../com/linkedin/metadata/EventUtils.java | 2 +- .../golden_dataproduct_out_upsert.json | 56 +- metadata-io/build.gradle | 1 - .../entity/ebean/batch/MCLItemImpl.java | 24 + .../entity/validation/ValidationApiUtils.java | 4 +- .../metadata/entity/EntityServiceImpl.java | 6 +- .../metadata/entity/ebean/EbeanAspectDao.java | 3 + .../sideeffects/SchemaFieldSideEffect.java | 627 + .../metadata/search/LineageSearchService.java | 41 +- .../elasticsearch/ElasticSearchService.java | 16 +- .../indexbuilder/EntityIndexBuilders.java | 3 +- .../metadata/search/utils/SearchUtils.java | 13 - .../service/UpdateIndicesService.java | 26 +- .../timeline/TimelineServiceImpl.java | 23 +- .../ChangeEventGeneratorUtils.java | 25 + ...DatasetPropertiesChangeEventGenerator.java | 2 +- ...DatasetPropertiesChangeEventGenerator.java | 2 +- ...bleSchemaMetadataChangeEventGenerator.java | 2 +- .../EntityChangeEventGenerator.java | 2 +- .../GlobalTagsChangeEventGenerator.java | 2 +- .../GlossaryTermInfoChangeEventGenerator.java | 2 +- .../GlossaryTermsChangeEventGenerator.java | 2 +- ...stitutionalMemoryChangeEventGenerator.java | 2 +- .../OwnershipChangeEventGenerator.java | 2 +- .../SchemaMetadataChangeEventGenerator.java | 2 +- .../SchemaFieldSideEffectTest.java | 713 + .../search/LineageServiceTestBase.java | 35 +- .../search/SearchServiceTestBase.java | 6 +- .../metadata/search/TestEntityTestBase.java | 6 +- .../metadata/search/query/BrowseDAOTest.java | 6 +- .../SystemMetadataServiceTestBase.java | 6 +- .../TimeseriesAspectServiceTestBase.java | 7 +- .../SampleDataFixtureConfiguration.java | 12 +- .../SearchLineageFixtureConfiguration.java | 34 +- .../test/search/SearchTestUtils.java | 6 + .../event/EntityChangeEventGeneratorHook.java | 17 +- .../kafka/hook/UpdateIndicesHookTest.java | 38 +- .../dataproduct/DataProductAssociation.pdl | 5 + .../linkedin/metadata/search/SearchEntity.pdl | 5 + .../pegasus/com/linkedin/post/PostInfo.pdl | 23 + .../schemafield/schemaFieldAliases.pdl | 22 + .../linkedin/schemafield/schemafieldInfo.pdl | 17 +- .../linkedin/upgrade/DataHubUpgradeResult.pdl | 5 + .../linkedin/upgrade/DataHubUpgradeState.pdl | 23 + .../src/main/resources/entity-registry.yml | 8 + .../metadata/context/SearchContextTest.java | 7 +- .../authentication/post/PostService.java | 27 +- .../authentication/post/PostServiceTest.java | 6 +- .../graphql/featureflags/FeatureFlags.java | 0 .../config/DataHubAppConfiguration.java | 57 + .../config/MetadataChangeProposalConfig.java | 13 + .../config/search/DocIdsConfiguration.java | 8 + .../search/ElasticSearchConfiguration.java | 1 + .../search/EntityDocIdConfiguration.java | 8 + .../config/search/IndexConfiguration.java | 9 + .../src/main/resources/application.yaml | 16 + .../common/IndexConventionFactory.java | 23 +- .../factory/config/ConfigurationProvider.java | 64 +- .../SystemOperationContextFactory.java | 13 +- .../SystemUpdateSchemaRegistryFactory.java | 13 +- .../SpringStandardPluginConfiguration.java | 52 +- .../search/LineageSearchServiceFactory.java | 2 +- .../linkedin/metadata/boot/BootstrapStep.java | 37 +- .../kafka/MockSystemUpdateSerializer.java | 8 +- .../boot/steps/IngestPoliciesStep.java | 10 +- .../datahub/graphql/GraphQLController.java | 4 + .../datahub/graphql/SpringQueryContext.java | 5 + .../com.linkedin.entity.aspects.snapshot.json | 2 +- ...com.linkedin.entity.entities.snapshot.json | 10 +- .../com.linkedin.entity.runs.snapshot.json | 2 +- ...nkedin.operations.operations.snapshot.json | 2 +- ...m.linkedin.platform.platform.snapshot.json | 2 +- .../restoreindices/RestoreIndicesArgs.java | 3 + .../metadata/search/EntitySearchService.java | 8 + .../metadata/search/utils/QueryUtils.java | 97 + .../metadata/service/FormService.java | 2 +- .../timeline/data/ChangeTransaction.java | 2 +- .../metadata/utils/SchemaFieldUtils.java | 114 +- .../utils/elasticsearch/IndexConvention.java | 10 + .../elasticsearch/IndexConventionImpl.java | 50 +- .../metadata/utils/SchemaFieldUtilsTest.java | 133 + .../IndexConventionImplTest.java | 37 +- .../tests/schema_fields/schema_evolution.py | 230 + .../schema_field_side_effect_data.json | 153085 +++++++++++++++ 143 files changed, 156992 insertions(+), 419 deletions(-) create mode 100644 datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/config/SchemaFieldsConfig.java create mode 100644 datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/schemafield/GenerateSchemaFieldsFromSchemaMetadata.java create mode 100644 datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/schemafield/GenerateSchemaFieldsFromSchemaMetadataStep.java create mode 100644 datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/schemafield/MigrateSchemaFieldDocIds.java create mode 100644 datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/schemafield/MigrateSchemaFieldDocIdsStep.java create mode 100644 datahub-upgrade/src/test/java/com/linkedin/datahub/upgrade/schemafield/GenerateSchemaFieldsFromSchemaMetadataStepTest.java create mode 100644 metadata-io/src/main/java/com/linkedin/metadata/schemafields/sideeffects/SchemaFieldSideEffect.java create mode 100644 metadata-io/src/test/java/com/linkedin/metadata/schemafields/sideeffects/SchemaFieldSideEffectTest.java create mode 100644 metadata-models/src/main/pegasus/com/linkedin/schemafield/schemaFieldAliases.pdl create mode 100644 metadata-models/src/main/pegasus/com/linkedin/upgrade/DataHubUpgradeState.pdl rename {datahub-graphql-core => metadata-service/configuration}/src/main/java/com/linkedin/datahub/graphql/featureflags/FeatureFlags.java (100%) create mode 100644 metadata-service/configuration/src/main/java/com/linkedin/metadata/config/DataHubAppConfiguration.java create mode 100644 metadata-service/configuration/src/main/java/com/linkedin/metadata/config/search/DocIdsConfiguration.java create mode 100644 metadata-service/configuration/src/main/java/com/linkedin/metadata/config/search/EntityDocIdConfiguration.java create mode 100644 metadata-service/configuration/src/main/java/com/linkedin/metadata/config/search/IndexConfiguration.java create mode 100644 metadata-utils/src/test/java/com/linkedin/metadata/utils/SchemaFieldUtilsTest.java create mode 100644 smoke-test/tests/schema_fields/schema_evolution.py create mode 100644 smoke-test/tests/schema_fields/schema_field_side_effect_data.json diff --git a/.github/workflows/docker-unified.yml b/.github/workflows/docker-unified.yml index c2adf628470e61..075da20cdd11cc 100644 --- a/.github/workflows/docker-unified.yml +++ b/.github/workflows/docker-unified.yml @@ -968,6 +968,13 @@ jobs: docker pull '${{ env.DATAHUB_ELASTIC_SETUP_IMAGE }}:head' docker tag '${{ env.DATAHUB_ELASTIC_SETUP_IMAGE }}:head' '${{ env.DATAHUB_ELASTIC_SETUP_IMAGE }}:${{ needs.setup.outputs.unique_tag }}' fi + if [ '${{ needs.setup.outputs.integrations_service_change }}' == 'false' ]; then + echo 'datahub-integration-service head images' + docker pull '${{ env.DATAHUB_INTEGRATIONS_IMAGE }}:head' + docker tag '${{ env.DATAHUB_INTEGRATIONS_IMAGE }}:head' '${{ env.DATAHUB_INTEGRATIONS_IMAGE }}:${{ needs.setup.outputs.unique_tag }}' + fi + - name: CI Slim Head Images + run: | if [ '${{ needs.setup.outputs.ingestion_change }}' == 'false' ]; then echo 'datahub-ingestion head-slim images' docker pull '${{ env.DATAHUB_INGESTION_IMAGE }}:head-slim' diff --git a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/QueryContext.java b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/QueryContext.java index 7dffd90cf2d7cc..5ad82b5d703757 100644 --- a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/QueryContext.java +++ b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/QueryContext.java @@ -3,6 +3,7 @@ import com.datahub.authentication.Actor; import com.datahub.authentication.Authentication; import com.datahub.plugins.auth.authorization.Authorizer; +import com.linkedin.metadata.config.DataHubAppConfiguration; import io.datahubproject.metadata.context.OperationContext; /** Provided as input to GraphQL resolvers; used to carry information about GQL request context. */ @@ -31,4 +32,6 @@ default String getActorUrn() { * @return Returns the operational context */ OperationContext getOperationContext(); + + DataHubAppConfiguration getDataHubAppConfig(); } diff --git a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/ResolverUtils.java b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/ResolverUtils.java index 3617eb47259797..346b353da93e47 100644 --- a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/ResolverUtils.java +++ b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/ResolverUtils.java @@ -7,7 +7,6 @@ import com.fasterxml.jackson.core.StreamReadConstraints; import com.fasterxml.jackson.databind.ObjectMapper; import com.google.common.collect.ImmutableSet; -import com.linkedin.common.urn.Urn; import com.linkedin.common.urn.UrnUtils; import com.linkedin.data.template.StringArray; import com.linkedin.datahub.graphql.QueryContext; @@ -23,7 +22,6 @@ import com.linkedin.metadata.query.filter.CriterionArray; import com.linkedin.metadata.query.filter.Filter; import com.linkedin.metadata.search.utils.ESUtils; -import com.linkedin.metadata.search.utils.QueryUtils; import com.linkedin.metadata.service.ViewService; import com.linkedin.view.DataHubViewInfo; import graphql.schema.DataFetchingEnvironment; @@ -222,27 +220,6 @@ private static String getFilterField( return ESUtils.toKeywordField(originalField, skipKeywordSuffix, aspectRetriever); } - public static Filter buildFilterWithUrns(@Nonnull Set urns, @Nullable Filter inputFilters) { - Criterion urnMatchCriterion = - new Criterion() - .setField("urn") - .setValue("") - .setValues( - new StringArray(urns.stream().map(Object::toString).collect(Collectors.toList()))); - if (inputFilters == null) { - return QueryUtils.newFilter(urnMatchCriterion); - } - - // Add urn match criterion to each or clause - if (inputFilters.getOr() != null && !inputFilters.getOr().isEmpty()) { - for (ConjunctiveCriterion conjunctiveCriterion : inputFilters.getOr()) { - conjunctiveCriterion.getAnd().add(urnMatchCriterion); - } - return inputFilters; - } - return QueryUtils.newFilter(urnMatchCriterion); - } - public static Filter viewFilter( OperationContext opContext, ViewService viewService, String viewUrn) { if (viewUrn == null) { diff --git a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/assertion/UpsertCustomAssertionResolver.java b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/assertion/UpsertCustomAssertionResolver.java index 026f486e32c116..29a9fff5e013a0 100644 --- a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/assertion/UpsertCustomAssertionResolver.java +++ b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/assertion/UpsertCustomAssertionResolver.java @@ -101,7 +101,7 @@ private CustomAssertionInfo createCustomAssertionInfo( if (input.getFieldPath() != null) { customAssertionInfo.setField( - SchemaFieldUtils.generateSchemaFieldUrn(entityUrn.toString(), input.getFieldPath())); + SchemaFieldUtils.generateSchemaFieldUrn(entityUrn, input.getFieldPath())); } return customAssertionInfo; } diff --git a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/dataproduct/ListDataProductAssetsResolver.java b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/dataproduct/ListDataProductAssetsResolver.java index 320d89cdec164a..5c43fafb678c5c 100644 --- a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/dataproduct/ListDataProductAssetsResolver.java +++ b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/dataproduct/ListDataProductAssetsResolver.java @@ -1,7 +1,7 @@ package com.linkedin.datahub.graphql.resolvers.dataproduct; import static com.linkedin.datahub.graphql.resolvers.ResolverUtils.bindArgument; -import static com.linkedin.datahub.graphql.resolvers.ResolverUtils.buildFilterWithUrns; +import static com.linkedin.metadata.search.utils.QueryUtils.buildFilterWithUrns; import com.google.common.collect.ImmutableList; import com.linkedin.common.urn.Urn; @@ -11,6 +11,8 @@ import com.linkedin.datahub.graphql.concurrency.GraphQLConcurrencyUtils; import com.linkedin.datahub.graphql.generated.DataProduct; import com.linkedin.datahub.graphql.generated.EntityType; +import com.linkedin.datahub.graphql.generated.ExtraProperty; +import com.linkedin.datahub.graphql.generated.FacetFilterInput; import com.linkedin.datahub.graphql.generated.SearchAcrossEntitiesInput; import com.linkedin.datahub.graphql.generated.SearchResults; import com.linkedin.datahub.graphql.resolvers.ResolverUtils; @@ -30,8 +32,12 @@ import java.util.Collections; import java.util.HashSet; import java.util.List; +import java.util.Optional; +import java.util.Set; import java.util.concurrent.CompletableFuture; import java.util.stream.Collectors; +import javax.annotation.Nonnull; +import javax.annotation.Nullable; import lombok.RequiredArgsConstructor; import lombok.extern.slf4j.Slf4j; @@ -44,6 +50,7 @@ public class ListDataProductAssetsResolver implements DataFetcher> { + private static final String OUTPUT_PORTS_FILTER_FIELD = "isOutputPort"; private static final int DEFAULT_START = 0; private static final int DEFAULT_COUNT = 10; @@ -63,6 +70,7 @@ public CompletableFuture get(DataFetchingEnvironment environment) // 1. Get urns of assets belonging to Data Product using an aspect query List assetUrns = new ArrayList<>(); + Set outputPorts = Collections.EMPTY_SET; try { final EntityResponse entityResponse = _entityClient.getV2( @@ -86,6 +94,11 @@ public CompletableFuture get(DataFetchingEnvironment environment) dataProductProperties.getAssets().stream() .map(DataProductAssociation::getDestinationUrn) .collect(Collectors.toList())); + outputPorts = + dataProductProperties.getAssets().stream() + .filter(DataProductAssociation::isOutputPort) + .map(dpa -> dpa.getDestinationUrn().toString()) + .collect(Collectors.toSet()); } } } catch (Exception e) { @@ -117,6 +130,7 @@ public CompletableFuture get(DataFetchingEnvironment environment) final int start = input.getStart() != null ? input.getStart() : DEFAULT_START; final int count = input.getCount() != null ? input.getCount() : DEFAULT_COUNT; + Set finalOutputPorts = outputPorts; return GraphQLConcurrencyUtils.supplyAsync( () -> { // if no assets in data product properties, exit early before search and return empty @@ -130,13 +144,21 @@ public CompletableFuture get(DataFetchingEnvironment environment) return results; } + List filters = input.getFilters(); + final List urnsToFilterOn = getUrnsToFilterOn(assetUrns, finalOutputPorts, filters); + // need to remove output ports filter so we don't send to elastic + if (filters != null) { + filters.removeIf(f -> f.getField().equals(OUTPUT_PORTS_FILTER_FIELD)); + } // add urns from the aspect to our filters final Filter baseFilter = ResolverUtils.buildFilter( - input.getFilters(), + filters, input.getOrFilters(), context.getOperationContext().getAspectRetriever()); - final Filter finalFilter = buildFilterWithUrns(new HashSet<>(assetUrns), baseFilter); + final Filter finalFilter = + buildFilterWithUrns( + context.getDataHubAppConfig(), new HashSet<>(urnsToFilterOn), baseFilter); final SearchFlags searchFlags; com.linkedin.datahub.graphql.generated.SearchFlags inputFlags = input.getSearchFlags(); @@ -155,18 +177,34 @@ public CompletableFuture get(DataFetchingEnvironment environment) start, count); - return UrnSearchResultsMapper.map( - context, - _entityClient.searchAcrossEntities( - context - .getOperationContext() - .withSearchFlags(flags -> searchFlags != null ? searchFlags : flags), - finalEntityNames, - sanitizedQuery, - finalFilter, - start, - count, - null)); + SearchResults results = + UrnSearchResultsMapper.map( + context, + _entityClient.searchAcrossEntities( + context + .getOperationContext() + .withSearchFlags(flags -> searchFlags != null ? searchFlags : flags), + finalEntityNames, + sanitizedQuery, + finalFilter, + start, + count, + null, + null)); + results + .getSearchResults() + .forEach( + searchResult -> { + if (finalOutputPorts.contains(searchResult.getEntity().getUrn())) { + if (searchResult.getExtraProperties() == null) { + searchResult.setExtraProperties(new ArrayList<>()); + } + searchResult + .getExtraProperties() + .add(new ExtraProperty("isOutputPort", "true")); + } + }); + return results; } catch (Exception e) { log.error( "Failed to execute search for data product assets: entity types {}, query {}, filters: {}, start: {}, count: {}", @@ -186,4 +224,37 @@ public CompletableFuture get(DataFetchingEnvironment environment) this.getClass().getSimpleName(), "get"); } + + /** + * Check to see if our filters list has a hardcoded filter for output ports. If so, let this + * filter determine which urns we filter search results on. Otherwise, if no output port filter is + * found, return all asset urns as per usual. + */ + @Nonnull + private List getUrnsToFilterOn( + @Nonnull final List assetUrns, + @Nonnull final Set outputPortUrns, + @Nullable final List filters) { + Optional isOutputPort = + filters != null + ? filters.stream() + .filter(f -> f.getField().equals(OUTPUT_PORTS_FILTER_FIELD)) + .findFirst() + : Optional.empty(); + + // optionally get entities that explicitly are or are not output ports + List urnsToFilterOn = assetUrns; + if (isOutputPort.isPresent()) { + if (isOutputPort.get().getValue().equals("true")) { + urnsToFilterOn = outputPortUrns.stream().map(UrnUtils::getUrn).collect(Collectors.toList()); + } else { + urnsToFilterOn = + assetUrns.stream() + .filter(u -> !outputPortUrns.contains(u.toString())) + .collect(Collectors.toList()); + } + } + + return urnsToFilterOn; + } } diff --git a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/post/CreatePostResolver.java b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/post/CreatePostResolver.java index 8b4253501dedc7..312950e44ffbda 100644 --- a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/post/CreatePostResolver.java +++ b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/post/CreatePostResolver.java @@ -5,15 +5,13 @@ import com.datahub.authentication.Authentication; import com.datahub.authentication.post.PostService; import com.linkedin.common.Media; +import com.linkedin.common.urn.UrnUtils; import com.linkedin.datahub.graphql.QueryContext; import com.linkedin.datahub.graphql.authorization.AuthorizationUtils; import com.linkedin.datahub.graphql.concurrency.GraphQLConcurrencyUtils; import com.linkedin.datahub.graphql.exception.AuthorizationException; -import com.linkedin.datahub.graphql.generated.CreatePostInput; -import com.linkedin.datahub.graphql.generated.PostContentType; -import com.linkedin.datahub.graphql.generated.PostType; -import com.linkedin.datahub.graphql.generated.UpdateMediaInput; -import com.linkedin.datahub.graphql.generated.UpdatePostContentInput; +import com.linkedin.datahub.graphql.generated.*; +import com.linkedin.metadata.utils.SchemaFieldUtils; import com.linkedin.post.PostContent; import graphql.schema.DataFetcher; import graphql.schema.DataFetchingEnvironment; @@ -46,6 +44,18 @@ public CompletableFuture get(final DataFetchingEnvironment environment) final String description = content.getDescription(); final UpdateMediaInput updateMediaInput = content.getMedia(); final Authentication authentication = context.getAuthentication(); + final String targetResource = input.getResourceUrn(); + final String targetSubresource = input.getSubResource(); + + String targetUrn; + if (targetSubresource != null) { + targetUrn = + SchemaFieldUtils.generateSchemaFieldUrn( + UrnUtils.getUrn(targetResource), targetSubresource) + .toString(); + } else { + targetUrn = targetResource; + } Media media = updateMediaInput == null @@ -59,7 +69,7 @@ public CompletableFuture get(final DataFetchingEnvironment environment) () -> { try { return _postService.createPost( - context.getOperationContext(), type.toString(), postContent); + context.getOperationContext(), type.toString(), postContent, targetUrn); } catch (Exception e) { throw new RuntimeException("Failed to create a new post", e); } diff --git a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/types/dataset/mappers/SchemaFieldMapper.java b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/types/dataset/mappers/SchemaFieldMapper.java index 3674186ac23fe6..23d94ff85bd3d4 100644 --- a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/types/dataset/mappers/SchemaFieldMapper.java +++ b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/types/dataset/mappers/SchemaFieldMapper.java @@ -91,8 +91,7 @@ private SchemaFieldEntity createSchemaFieldEntity( @Nonnull final com.linkedin.schema.SchemaField input, @Nonnull Urn entityUrn) { SchemaFieldEntity schemaFieldEntity = new SchemaFieldEntity(); schemaFieldEntity.setUrn( - SchemaFieldUtils.generateSchemaFieldUrn(entityUrn.toString(), input.getFieldPath()) - .toString()); + SchemaFieldUtils.generateSchemaFieldUrn(entityUrn, input.getFieldPath()).toString()); schemaFieldEntity.setType(EntityType.SCHEMA_FIELD); return schemaFieldEntity; } diff --git a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/types/mappers/MapperUtils.java b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/types/mappers/MapperUtils.java index 7dd12d62765c60..0eb74210971d9f 100644 --- a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/types/mappers/MapperUtils.java +++ b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/types/mappers/MapperUtils.java @@ -5,9 +5,11 @@ import com.linkedin.common.UrnArray; import com.linkedin.common.urn.Urn; +import com.linkedin.data.template.StringMap; import com.linkedin.datahub.graphql.QueryContext; import com.linkedin.datahub.graphql.generated.AggregationMetadata; import com.linkedin.datahub.graphql.generated.EntityPath; +import com.linkedin.datahub.graphql.generated.ExtraProperty; import com.linkedin.datahub.graphql.generated.FacetMetadata; import com.linkedin.datahub.graphql.generated.MatchedField; import com.linkedin.datahub.graphql.generated.SearchResult; @@ -35,7 +37,24 @@ public static SearchResult mapResult( return new SearchResult( UrnToEntityMapper.map(context, searchEntity.getEntity()), getInsightsFromFeatures(searchEntity.getFeatures()), - getMatchedFieldEntry(context, searchEntity.getMatchedFields())); + getMatchedFieldEntry(context, searchEntity.getMatchedFields()), + getExtraProperties(searchEntity.getExtraFields())); + } + + private static List getExtraProperties(@Nullable StringMap extraFields) { + if (extraFields == null) { + return List.of(); + } else { + return extraFields.entrySet().stream() + .map( + entry -> { + ExtraProperty extraProperty = new ExtraProperty(); + extraProperty.setName(entry.getKey()); + extraProperty.setValue(entry.getValue()); + return extraProperty; + }) + .collect(Collectors.toList()); + } } public static FacetMetadata mapFacet( diff --git a/datahub-graphql-core/src/main/resources/entity.graphql b/datahub-graphql-core/src/main/resources/entity.graphql index 609597beee51bd..52e81f8094dea6 100644 --- a/datahub-graphql-core/src/main/resources/entity.graphql +++ b/datahub-graphql-core/src/main/resources/entity.graphql @@ -11274,6 +11274,21 @@ input CreatePostInput { The content of the post """ content: UpdatePostContentInput! + + """ + Optional target URN for the post + """ + resourceUrn: String + + """ + An optional type of a sub resource to attach the Tag to + """ + subResourceType: SubResourceType + + """ + Optional target subresource for the post + """ + subResource: String } """ diff --git a/datahub-graphql-core/src/main/resources/search.graphql b/datahub-graphql-core/src/main/resources/search.graphql index 09a7217073527b..84e81e9096a3b9 100644 --- a/datahub-graphql-core/src/main/resources/search.graphql +++ b/datahub-graphql-core/src/main/resources/search.graphql @@ -582,6 +582,18 @@ type SearchResults { suggestions: [SearchSuggestion!] } +type ExtraProperty { + """ + Name of the extra property + """ + name: String! + + """ + Value of the extra property + """ + value: String! +} + """ An individual search result hit """ @@ -600,6 +612,11 @@ type SearchResult { Matched field hint """ matchedFields: [MatchedField!]! + + """ + Additional properties about the search result. Used for rendering in the UI + """ + extraProperties: [ExtraProperty!] } """ diff --git a/datahub-graphql-core/src/test/java/com/linkedin/datahub/graphql/resolvers/ResolverUtilsTest.java b/datahub-graphql-core/src/test/java/com/linkedin/datahub/graphql/resolvers/ResolverUtilsTest.java index f98284e92ede58..b01aacaaab65ca 100644 --- a/datahub-graphql-core/src/test/java/com/linkedin/datahub/graphql/resolvers/ResolverUtilsTest.java +++ b/datahub-graphql-core/src/test/java/com/linkedin/datahub/graphql/resolvers/ResolverUtilsTest.java @@ -1,6 +1,7 @@ package com.linkedin.datahub.graphql.resolvers; import static com.linkedin.datahub.graphql.resolvers.ResolverUtils.*; +import static com.linkedin.metadata.search.utils.QueryUtils.buildFilterWithUrns; import static org.mockito.Mockito.mock; import static org.testng.AssertJUnit.assertEquals; @@ -13,6 +14,8 @@ import com.linkedin.datahub.graphql.generated.FacetFilterInput; import com.linkedin.datahub.graphql.generated.FilterOperator; import com.linkedin.metadata.aspect.AspectRetriever; +import com.linkedin.metadata.config.DataHubAppConfiguration; +import com.linkedin.metadata.config.MetadataChangeProposalConfig; import com.linkedin.metadata.query.filter.Condition; import com.linkedin.metadata.query.filter.ConjunctiveCriterion; import com.linkedin.metadata.query.filter.ConjunctiveCriterionArray; @@ -102,7 +105,18 @@ public void testBuildFilterWithUrns() throws Exception { new ConjunctiveCriterionArray( ImmutableList.of(new ConjunctiveCriterion().setAnd(andCriterionArray)))); - Filter finalFilter = buildFilterWithUrns(urns, filter); + DataHubAppConfiguration appConfig = new DataHubAppConfiguration(); + appConfig.setMetadataChangeProposal(new MetadataChangeProposalConfig()); + appConfig + .getMetadataChangeProposal() + .setSideEffects(new MetadataChangeProposalConfig.SideEffectsConfig()); + appConfig + .getMetadataChangeProposal() + .getSideEffects() + .setSchemaField(new MetadataChangeProposalConfig.SideEffectConfig()); + appConfig.getMetadataChangeProposal().getSideEffects().getSchemaField().setEnabled(true); + + Filter finalFilter = buildFilterWithUrns(appConfig, urns, filter); Criterion urnsCriterion = new Criterion() diff --git a/datahub-graphql-core/src/test/java/com/linkedin/datahub/graphql/resolvers/datacontract/DataContractUtilsTest.java b/datahub-graphql-core/src/test/java/com/linkedin/datahub/graphql/resolvers/datacontract/DataContractUtilsTest.java index 18ede7c306e424..646c72422aa618 100644 --- a/datahub-graphql-core/src/test/java/com/linkedin/datahub/graphql/resolvers/datacontract/DataContractUtilsTest.java +++ b/datahub-graphql-core/src/test/java/com/linkedin/datahub/graphql/resolvers/datacontract/DataContractUtilsTest.java @@ -12,6 +12,7 @@ import com.linkedin.common.urn.Urn; import com.linkedin.common.urn.UrnUtils; import com.linkedin.datahub.graphql.QueryContext; +import com.linkedin.metadata.config.DataHubAppConfiguration; import graphql.Assert; import io.datahubproject.metadata.context.OperationContext; import io.datahubproject.test.metadata.context.TestOperationContexts; @@ -56,6 +57,11 @@ public OperationContext getOperationContext() { return TestOperationContexts.userContextNoSearchAuthorization( getAuthorizer(), getAuthentication()); } + + @Override + public DataHubAppConfiguration getDataHubAppConfig() { + return new DataHubAppConfiguration(); + } }, testUrn); Assert.assertTrue(result); diff --git a/datahub-graphql-core/src/test/java/com/linkedin/datahub/graphql/resolvers/post/CreatePostResolverTest.java b/datahub-graphql-core/src/test/java/com/linkedin/datahub/graphql/resolvers/post/CreatePostResolverTest.java index 7f14193737e00e..8e160237d095bf 100644 --- a/datahub-graphql-core/src/test/java/com/linkedin/datahub/graphql/resolvers/post/CreatePostResolverTest.java +++ b/datahub-graphql-core/src/test/java/com/linkedin/datahub/graphql/resolvers/post/CreatePostResolverTest.java @@ -94,7 +94,7 @@ public void testCreatePost() throws Exception { input.setContent(content); when(_dataFetchingEnvironment.getArgument(eq("input"))).thenReturn(input); when(_postService.createPost( - any(), eq(PostType.HOME_PAGE_ANNOUNCEMENT.toString()), eq(postContentObj))) + any(), eq(PostType.HOME_PAGE_ANNOUNCEMENT.toString()), eq(postContentObj), any())) .thenReturn(true); assertTrue(_resolver.get(_dataFetchingEnvironment).join()); diff --git a/datahub-upgrade/build.gradle b/datahub-upgrade/build.gradle index b66371db73386f..5d814dd876679e 100644 --- a/datahub-upgrade/build.gradle +++ b/datahub-upgrade/build.gradle @@ -115,7 +115,10 @@ task run(type: Exec) { environment "ENTITY_REGISTRY_CONFIG_PATH", "../metadata-models/src/main/resources/entity-registry.yml" environment "ENABLE_STRUCTURED_PROPERTIES_SYSTEM_UPDATE", "true" environment "ELASTICSEARCH_INDEX_BUILDER_MAPPINGS_REINDEX", "true" - commandLine "java", "-jar", "-Dserver.port=8083", bootJar.getArchiveFile().get(), "-u", "SystemUpdate" + commandLine "java", + "-agentlib:jdwp=transport=dt_socket,address=5003,server=y,suspend=n", + "-jar", + "-Dserver.port=8083", bootJar.getArchiveFile().get(), "-u", "SystemUpdate" } docker { diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/Upgrade.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/Upgrade.java index d3aea2a3dac12a..d159622eb292b6 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/Upgrade.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/Upgrade.java @@ -1,7 +1,17 @@ package com.linkedin.datahub.upgrade; import com.google.common.collect.ImmutableList; +import com.linkedin.common.urn.Urn; +import com.linkedin.metadata.boot.BootstrapStep; +import com.linkedin.metadata.entity.EntityService; +import com.linkedin.upgrade.DataHubUpgradeResult; +import com.linkedin.upgrade.DataHubUpgradeState; +import io.datahubproject.metadata.context.OperationContext; import java.util.List; +import java.util.Map; +import java.util.Optional; +import javax.annotation.Nonnull; +import javax.annotation.Nullable; /** Specification of an upgrade to be performed to the DataHub platform. */ public interface Upgrade { @@ -16,4 +26,18 @@ public interface Upgrade { default List cleanupSteps() { return ImmutableList.of(); } + + default Optional getUpgradeResult( + @Nonnull OperationContext opContext, Urn upgradeId, EntityService entityService) { + return BootstrapStep.getUpgradeResult(opContext, upgradeId, entityService); + } + + default void setUpgradeResult( + @Nonnull OperationContext opContext, + @Nonnull Urn upgradeId, + EntityService entityService, + @Nullable DataHubUpgradeState state, + @Nullable Map result) { + BootstrapStep.setUpgradeResult(opContext, upgradeId, entityService, state, result); + } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/UpgradeCli.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/UpgradeCli.java index 6d10a7ed6b3b48..bff65fd03dd572 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/UpgradeCli.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/UpgradeCli.java @@ -9,6 +9,7 @@ import com.linkedin.datahub.upgrade.system.SystemUpdate; import com.linkedin.datahub.upgrade.system.SystemUpdateBlocking; import com.linkedin.datahub.upgrade.system.SystemUpdateNonBlocking; +import com.linkedin.upgrade.DataHubUpgradeState; import io.datahubproject.metadata.context.OperationContext; import java.util.List; import javax.inject.Inject; @@ -91,7 +92,7 @@ public void run(String... cmdLineArgs) { UpgradeResult result = _upgradeManager.execute(systemOperationContext, args.upgradeId.trim(), args.args); - if (UpgradeResult.Result.FAILED.equals(result.result())) { + if (DataHubUpgradeState.FAILED.equals(result.result())) { System.exit(1); } else { System.exit(0); diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/UpgradeContext.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/UpgradeContext.java index 73643175ab9c67..2b5598184ee6b9 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/UpgradeContext.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/UpgradeContext.java @@ -23,6 +23,6 @@ public interface UpgradeContext { /** Returns a map of argument to <>optional value, as delimited by an '=' character. */ Map> parsedArgs(); - /** Returns the operation context ffor the upgrade */ + /** Returns the operation context for the upgrade */ OperationContext opContext(); } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/UpgradeResult.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/UpgradeResult.java index 25dc758575fd16..57a01b4de413fa 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/UpgradeResult.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/UpgradeResult.java @@ -1,20 +1,12 @@ package com.linkedin.datahub.upgrade; +import com.linkedin.upgrade.DataHubUpgradeState; + /** Represents the result of executing an {@link Upgrade} */ public interface UpgradeResult { - /** The execution result. */ - enum Result { - /** Upgrade succeeded. */ - SUCCEEDED, - /** Upgrade failed. */ - FAILED, - /** Upgrade was aborted. */ - ABORTED - } - - /** Returns the {@link Result} of executing an {@link Upgrade} */ - Result result(); + /** Returns the {@link DataHubUpgradeState} of executing an {@link Upgrade} */ + DataHubUpgradeState result(); /** Returns the {@link UpgradeReport} associated with the completed {@link Upgrade}. */ UpgradeReport report(); diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/UpgradeStepResult.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/UpgradeStepResult.java index 04b3d4b8559e67..e88e3c75f86954 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/UpgradeStepResult.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/UpgradeStepResult.java @@ -1,18 +1,12 @@ package com.linkedin.datahub.upgrade; +import com.linkedin.upgrade.DataHubUpgradeState; + public interface UpgradeStepResult { /** Returns a string identifier associated with the step. */ String stepId(); - /** The outcome of the step execution. */ - enum Result { - /** The step succeeded. */ - SUCCEEDED, - /** The step failed. */ - FAILED - } - /** A control-flow action to perform as a result of the step execution. */ enum Action { /** Continue attempting the upgrade. */ @@ -24,7 +18,7 @@ enum Action { } /** Returns the result of executing the step, either success or failure. */ - Result result(); + DataHubUpgradeState result(); /** Returns the action to perform after executing the step, either continue or abort. */ default Action action() { diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/ClearGraphServiceStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/ClearGraphServiceStep.java index 393b5411599adc..357f1ffd663a9a 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/ClearGraphServiceStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/ClearGraphServiceStep.java @@ -6,6 +6,7 @@ import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; import com.linkedin.datahub.upgrade.nocode.NoCodeUpgrade; import com.linkedin.metadata.graph.GraphService; +import com.linkedin.upgrade.DataHubUpgradeState; import java.util.function.Function; public class ClearGraphServiceStep implements UpgradeStep { @@ -49,9 +50,9 @@ public Function executable() { _graphService.clear(); } catch (Exception e) { context.report().addLine("Failed to clear graph indices", e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/ClearSearchServiceStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/ClearSearchServiceStep.java index 44592ecf92dbda..0ccd2029c93ac3 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/ClearSearchServiceStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/ClearSearchServiceStep.java @@ -6,6 +6,7 @@ import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; import com.linkedin.datahub.upgrade.nocode.NoCodeUpgrade; import com.linkedin.metadata.search.EntitySearchService; +import com.linkedin.upgrade.DataHubUpgradeState; import java.util.function.Function; public class ClearSearchServiceStep implements UpgradeStep { @@ -48,9 +49,9 @@ public Function executable() { _entitySearchService.clear(context.opContext()); } catch (Exception e) { context.report().addLine("Failed to clear search service", e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/ClearSystemMetadataServiceStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/ClearSystemMetadataServiceStep.java index 889d2f0a79edf6..f0f2958e917330 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/ClearSystemMetadataServiceStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/ClearSystemMetadataServiceStep.java @@ -6,6 +6,7 @@ import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; import com.linkedin.datahub.upgrade.nocode.NoCodeUpgrade; import com.linkedin.metadata.systemmetadata.SystemMetadataService; +import com.linkedin.upgrade.DataHubUpgradeState; import java.util.function.Function; public class ClearSystemMetadataServiceStep implements UpgradeStep { @@ -48,9 +49,9 @@ public Function executable() { _systemMetadataService.clear(); } catch (Exception e) { context.report().addLine("Failed to clear system metadata service", e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/GMSDisableWriteModeStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/GMSDisableWriteModeStep.java index a80adabc60e743..2e31d1eb62bd0c 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/GMSDisableWriteModeStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/GMSDisableWriteModeStep.java @@ -5,6 +5,7 @@ import com.linkedin.datahub.upgrade.UpgradeStepResult; import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; import com.linkedin.entity.client.SystemEntityClient; +import com.linkedin.upgrade.DataHubUpgradeState; import java.util.function.Function; import lombok.RequiredArgsConstructor; import lombok.extern.slf4j.Slf4j; @@ -33,9 +34,9 @@ public Function executable() { } catch (Exception e) { log.error("Failed to turn write mode off in GMS", e); context.report().addLine("Failed to turn write mode off in GMS"); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/GMSEnableWriteModeStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/GMSEnableWriteModeStep.java index a6b2942fabffd7..12bfccf1c6749a 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/GMSEnableWriteModeStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/GMSEnableWriteModeStep.java @@ -5,6 +5,7 @@ import com.linkedin.datahub.upgrade.UpgradeStepResult; import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; import com.linkedin.entity.client.SystemEntityClient; +import com.linkedin.upgrade.DataHubUpgradeState; import java.util.function.Function; import lombok.RequiredArgsConstructor; import lombok.extern.slf4j.Slf4j; @@ -32,9 +33,9 @@ public Function executable() { } catch (Exception e) { log.error("Failed to turn write mode back on in GMS", e); context.report().addLine("Failed to turn write mode back on in GMS"); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/GMSQualificationStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/GMSQualificationStep.java index 4e7447cb1e2cb6..9ee8244ee370d0 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/GMSQualificationStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/common/steps/GMSQualificationStep.java @@ -10,6 +10,7 @@ import com.linkedin.datahub.upgrade.UpgradeStep; import com.linkedin.datahub.upgrade.UpgradeStepResult; import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; +import com.linkedin.upgrade.DataHubUpgradeState; import java.io.BufferedReader; import java.io.IOException; import java.io.InputStream; @@ -97,7 +98,7 @@ public Function executable() { StreamReadConstraints.builder().maxStringLength(maxSize).build()); JsonNode configJson = mapper.readTree(responseString); if (isEligible((ObjectNode) configJson)) { - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); } else { context .report() @@ -105,7 +106,7 @@ public Function executable() { String.format( "Failed to qualify GMS. It is not running on the latest version." + "Re-run GMS on the latest datahub release")); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } } catch (Exception e) { e.printStackTrace(); @@ -117,7 +118,7 @@ public Function executable() { + "at %s://host %s port %s. Make sure GMS is on the latest version " + "and is running at that host before starting the migration.", gmsProtocol, gmsHost, gmsPort)); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } }; } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/config/SchemaFieldsConfig.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/config/SchemaFieldsConfig.java new file mode 100644 index 00000000000000..5630379c566183 --- /dev/null +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/config/SchemaFieldsConfig.java @@ -0,0 +1,56 @@ +package com.linkedin.datahub.upgrade.config; + +import com.linkedin.datahub.upgrade.system.NonBlockingSystemUpgrade; +import com.linkedin.datahub.upgrade.system.schemafield.GenerateSchemaFieldsFromSchemaMetadata; +import com.linkedin.datahub.upgrade.system.schemafield.MigrateSchemaFieldDocIds; +import com.linkedin.gms.factory.search.BaseElasticSearchComponentsFactory; +import com.linkedin.metadata.entity.AspectDao; +import com.linkedin.metadata.entity.EntityService; +import io.datahubproject.metadata.context.OperationContext; +import org.springframework.beans.factory.annotation.Qualifier; +import org.springframework.beans.factory.annotation.Value; +import org.springframework.context.annotation.Bean; +import org.springframework.context.annotation.Conditional; +import org.springframework.context.annotation.Configuration; + +@Configuration +@Conditional(SystemUpdateCondition.NonBlockingSystemUpdateCondition.class) +public class SchemaFieldsConfig { + + @Bean + public NonBlockingSystemUpgrade schemaFieldsFromSchemaMetadata( + @Qualifier("systemOperationContext") final OperationContext opContext, + final EntityService entityService, + final AspectDao aspectDao, + // SYSTEM_UPDATE_SCHEMA_FIELDS_FROM_SCHEMA_METADATA_ENABLED + @Value("${systemUpdate.schemaFieldsFromSchemaMetadata.enabled}") final boolean enabled, + // SYSTEM_UPDATE_SCHEMA_FIELDS_FROM_SCHEMA_METADATA_BATCH_SIZE + @Value("${systemUpdate.schemaFieldsFromSchemaMetadata.batchSize}") final Integer batchSize, + // SYSTEM_UPDATE_SCHEMA_FIELDS_FROM_SCHEMA_METADATA_DELAY_MS + @Value("${systemUpdate.schemaFieldsFromSchemaMetadata.delayMs}") final Integer delayMs, + // SYSTEM_UPDATE_SCHEMA_FIELDS_FROM_SCHEMA_METADATA_LIMIT + @Value("${systemUpdate.schemaFieldsFromSchemaMetadata.limit}") final Integer limit) { + return new GenerateSchemaFieldsFromSchemaMetadata( + opContext, entityService, aspectDao, enabled, batchSize, delayMs, limit); + } + + @Bean + public NonBlockingSystemUpgrade schemaFieldsDocIds( + @Qualifier("systemOperationContext") final OperationContext opContext, + @Qualifier("baseElasticSearchComponents") + final BaseElasticSearchComponentsFactory.BaseElasticSearchComponents components, + final EntityService entityService, + // ELASTICSEARCH_INDEX_DOC_IDS_SCHEMA_FIELD_HASH_ID_ENABLED + @Value("${elasticsearch.index.docIds.schemaField.hashIdEnabled}") final boolean hashEnabled, + // SYSTEM_UPDATE_SCHEMA_FIELDS_DOC_IDS_ENABLED + @Value("${systemUpdate.schemaFieldsDocIds.enabled}") final boolean enabled, + // SYSTEM_UPDATE_SCHEMA_FIELDS_DOC_IDS_BATCH_SIZE + @Value("${systemUpdate.schemaFieldsDocIds.batchSize}") final Integer batchSize, + // SYSTEM_UPDATE_SCHEMA_FIELDS_DOC_IDS_DELAY_MS + @Value("${systemUpdate.schemaFieldsDocIds.delayMs}") final Integer delayMs, + // SYSTEM_UPDATE_SCHEMA_FIELDS_DOC_IDS_LIMIT + @Value("${systemUpdate.schemaFieldsDocIds.limit}") final Integer limit) { + return new MigrateSchemaFieldDocIds( + opContext, components, entityService, enabled && hashEnabled, batchSize, delayMs, limit); + } +} diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/config/SystemUpdateConfig.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/config/SystemUpdateConfig.java index cac9b5f9483d41..9c0c82dba65be6 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/config/SystemUpdateConfig.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/config/SystemUpdateConfig.java @@ -1,5 +1,6 @@ package com.linkedin.datahub.upgrade.config; +import com.datahub.authentication.Authentication; import com.linkedin.datahub.upgrade.system.BlockingSystemUpgrade; import com.linkedin.datahub.upgrade.system.NonBlockingSystemUpgrade; import com.linkedin.datahub.upgrade.system.SystemUpdate; @@ -11,12 +12,25 @@ import com.linkedin.gms.factory.kafka.common.TopicConventionFactory; import com.linkedin.gms.factory.kafka.schemaregistry.InternalSchemaRegistryFactory; import com.linkedin.gms.factory.kafka.schemaregistry.SchemaRegistryConfig; +import com.linkedin.gms.factory.search.BaseElasticSearchComponentsFactory; +import com.linkedin.metadata.aspect.GraphRetriever; import com.linkedin.metadata.config.kafka.KafkaConfiguration; import com.linkedin.metadata.dao.producer.KafkaEventProducer; import com.linkedin.metadata.dao.producer.KafkaHealthChecker; +import com.linkedin.metadata.entity.EntityService; +import com.linkedin.metadata.entity.EntityServiceAspectRetriever; +import com.linkedin.metadata.models.registry.EntityRegistry; +import com.linkedin.metadata.search.SearchService; +import com.linkedin.metadata.search.SearchServiceSearchRetriever; import com.linkedin.metadata.version.GitVersion; import com.linkedin.mxe.TopicConvention; +import io.datahubproject.metadata.context.OperationContext; +import io.datahubproject.metadata.context.OperationContextConfig; +import io.datahubproject.metadata.context.RetrieverContext; +import io.datahubproject.metadata.context.ServicesRegistryContext; +import io.datahubproject.metadata.services.RestrictedService; import java.util.List; +import javax.annotation.Nonnull; import lombok.extern.slf4j.Slf4j; import org.apache.avro.generic.IndexedRecord; import org.apache.kafka.clients.producer.KafkaProducer; @@ -120,4 +134,46 @@ protected SchemaRegistryConfig schemaRegistryConfig( @Qualifier("duheSchemaRegistryConfig") SchemaRegistryConfig duheSchemaRegistryConfig) { return duheSchemaRegistryConfig; } + + @Primary + @Nonnull + @Bean(name = "systemOperationContext") + protected OperationContext javaSystemOperationContext( + @Nonnull @Qualifier("systemAuthentication") final Authentication systemAuthentication, + @Nonnull final OperationContextConfig operationContextConfig, + @Nonnull final EntityRegistry entityRegistry, + @Nonnull final EntityService entityService, + @Nonnull final RestrictedService restrictedService, + @Nonnull final GraphRetriever graphRetriever, + @Nonnull final SearchService searchService, + @Qualifier("baseElasticSearchComponents") + BaseElasticSearchComponentsFactory.BaseElasticSearchComponents components) { + + EntityServiceAspectRetriever entityServiceAspectRetriever = + EntityServiceAspectRetriever.builder() + .entityRegistry(entityRegistry) + .entityService(entityService) + .build(); + + SearchServiceSearchRetriever searchServiceSearchRetriever = + SearchServiceSearchRetriever.builder().searchService(searchService).build(); + + OperationContext systemOperationContext = + OperationContext.asSystem( + operationContextConfig, + systemAuthentication, + entityServiceAspectRetriever.getEntityRegistry(), + ServicesRegistryContext.builder().restrictedService(restrictedService).build(), + components.getIndexConvention(), + RetrieverContext.builder() + .aspectRetriever(entityServiceAspectRetriever) + .graphRetriever(graphRetriever) + .searchRetriever(searchServiceSearchRetriever) + .build()); + + entityServiceAspectRetriever.setSystemOperationContext(systemOperationContext); + searchServiceSearchRetriever.setSystemOperationContext(systemOperationContext); + + return systemOperationContext; + } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/impl/DefaultUpgradeManager.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/impl/DefaultUpgradeManager.java index 240ec9f7bb2fed..27ba6abbc5ba93 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/impl/DefaultUpgradeManager.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/impl/DefaultUpgradeManager.java @@ -11,6 +11,7 @@ import com.linkedin.datahub.upgrade.UpgradeStep; import com.linkedin.datahub.upgrade.UpgradeStepResult; import com.linkedin.metadata.utils.metrics.MetricUtils; +import com.linkedin.upgrade.DataHubUpgradeState; import io.datahubproject.metadata.context.OperationContext; import java.util.ArrayList; import java.util.HashMap; @@ -85,11 +86,11 @@ private UpgradeResult executeInternal(UpgradeContext context) { String.format( "Step with id %s requested an abort of the in-progress update. Aborting the upgrade...", step.id())); - return new DefaultUpgradeResult(UpgradeResult.Result.ABORTED, upgradeReport); + return new DefaultUpgradeResult(DataHubUpgradeState.ABORTED, upgradeReport); } // Handle Results - if (UpgradeStepResult.Result.FAILED.equals(stepResult.result())) { + if (DataHubUpgradeState.FAILED.equals(stepResult.result())) { if (step.isOptional()) { upgradeReport.addLine( String.format( @@ -104,7 +105,7 @@ private UpgradeResult executeInternal(UpgradeContext context) { "Failed Step %s/%s: %s. Failed after %s retries.", i + 1, steps.size(), step.id(), step.retryCount())); upgradeReport.addLine(String.format("Exiting upgrade %s with failure.", upgrade.id())); - return new DefaultUpgradeResult(UpgradeResult.Result.FAILED, upgradeReport); + return new DefaultUpgradeResult(DataHubUpgradeState.FAILED, upgradeReport); } upgradeReport.addLine( @@ -113,7 +114,7 @@ private UpgradeResult executeInternal(UpgradeContext context) { upgradeReport.addLine( String.format("Success! Completed upgrade with id %s successfully.", upgrade.id())); - return new DefaultUpgradeResult(UpgradeResult.Result.SUCCEEDED, upgradeReport); + return new DefaultUpgradeResult(DataHubUpgradeState.SUCCEEDED, upgradeReport); } private UpgradeStepResult executeStepInternal(UpgradeContext context, UpgradeStep step) { @@ -130,14 +131,14 @@ private UpgradeStepResult executeStepInternal(UpgradeContext context, UpgradeSte if (result == null) { // Failed to even retrieve a result. Create a default failure result. - result = new DefaultUpgradeStepResult(step.id(), UpgradeStepResult.Result.FAILED); + result = new DefaultUpgradeStepResult(step.id(), DataHubUpgradeState.FAILED); context .report() .addLine(String.format("Retrying %s more times...", maxAttempts - (i + 1))); MetricUtils.counter(MetricRegistry.name(step.id(), "retry")).inc(); } - if (UpgradeStepResult.Result.SUCCEEDED.equals(result.result())) { + if (DataHubUpgradeState.SUCCEEDED.equals(result.result())) { MetricUtils.counter(MetricRegistry.name(step.id(), "succeeded")).inc(); break; } @@ -149,7 +150,7 @@ private UpgradeStepResult executeStepInternal(UpgradeContext context, UpgradeSte String.format( "Caught exception during attempt %s of Step with id %s: %s", i, step.id(), e)); MetricUtils.counter(MetricRegistry.name(step.id(), "failed")).inc(); - result = new DefaultUpgradeStepResult(step.id(), UpgradeStepResult.Result.FAILED); + result = new DefaultUpgradeStepResult(step.id(), DataHubUpgradeState.FAILED); context.report().addLine(String.format("Retrying %s more times...", maxAttempts - (i + 1))); } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/impl/DefaultUpgradeResult.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/impl/DefaultUpgradeResult.java index cf0e7221b406b0..5131cadf5d3fa7 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/impl/DefaultUpgradeResult.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/impl/DefaultUpgradeResult.java @@ -2,19 +2,20 @@ import com.linkedin.datahub.upgrade.UpgradeReport; import com.linkedin.datahub.upgrade.UpgradeResult; +import com.linkedin.upgrade.DataHubUpgradeState; public class DefaultUpgradeResult implements UpgradeResult { - private final Result _result; + private final DataHubUpgradeState _result; private final UpgradeReport _report; - DefaultUpgradeResult(Result result, UpgradeReport report) { + DefaultUpgradeResult(DataHubUpgradeState result, UpgradeReport report) { _result = result; _report = report; } @Override - public Result result() { + public DataHubUpgradeState result() { return _result; } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/impl/DefaultUpgradeStepResult.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/impl/DefaultUpgradeStepResult.java index e11eaf89bfc8d2..cab0708fa52249 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/impl/DefaultUpgradeStepResult.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/impl/DefaultUpgradeStepResult.java @@ -1,18 +1,19 @@ package com.linkedin.datahub.upgrade.impl; import com.linkedin.datahub.upgrade.UpgradeStepResult; +import com.linkedin.upgrade.DataHubUpgradeState; public class DefaultUpgradeStepResult implements UpgradeStepResult { private final String _stepId; - private final Result _result; + private final DataHubUpgradeState _result; private final Action _action; - public DefaultUpgradeStepResult(String stepId, Result result) { + public DefaultUpgradeStepResult(String stepId, DataHubUpgradeState result) { this(stepId, result, Action.CONTINUE); } - public DefaultUpgradeStepResult(String stepId, Result result, Action action) { + public DefaultUpgradeStepResult(String stepId, DataHubUpgradeState result, Action action) { _stepId = stepId; _result = result; _action = action; @@ -24,7 +25,7 @@ public String stepId() { } @Override - public Result result() { + public DataHubUpgradeState result() { return _result; } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocode/CreateAspectTableStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocode/CreateAspectTableStep.java index 3b3098f43c4734..4855cef95cb6e5 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocode/CreateAspectTableStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocode/CreateAspectTableStep.java @@ -4,6 +4,7 @@ import com.linkedin.datahub.upgrade.UpgradeStep; import com.linkedin.datahub.upgrade.UpgradeStepResult; import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; +import com.linkedin.upgrade.DataHubUpgradeState; import io.ebean.Database; import java.util.function.Function; @@ -79,9 +80,9 @@ public Function executable() { _server.execute(_server.createSqlUpdate(sqlUpdateStr)); } catch (Exception e) { context.report().addLine("Failed to create table metadata_aspect_v2", e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocode/DataMigrationStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocode/DataMigrationStep.java index 94bf97f3c9c9e7..ecff2e3ee6e18b 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocode/DataMigrationStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocode/DataMigrationStep.java @@ -18,6 +18,7 @@ import com.linkedin.metadata.models.EntitySpec; import com.linkedin.metadata.models.registry.EntityRegistry; import com.linkedin.metadata.utils.PegasusUtils; +import com.linkedin.upgrade.DataHubUpgradeState; import com.linkedin.util.Pair; import io.ebean.Database; import io.ebean.PagedList; @@ -100,7 +101,7 @@ public Function executable() { "Failed to convert aspect with name %s into a RecordTemplate class", oldAspectName), e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } // 2. Extract an Entity type from the entity Urn @@ -127,7 +128,7 @@ public Function executable() { String.format( "Failed to find Entity with name %s in Entity Registry", entityName), e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } // 4. Extract new aspect name from Aspect schema @@ -142,7 +143,7 @@ public Function executable() { "Failed to retrieve @Aspect name from schema %s, urn %s", aspectRecord.schema().getFullName(), entityName), e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } // 5. Verify that the aspect is a valid aspect associated with the entity @@ -157,7 +158,7 @@ public Function executable() { "Failed to find aspect spec with name %s associated with entity named %s", newAspectName, entityName), e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } // 6. Write the row back using the EntityService @@ -214,9 +215,9 @@ public Function executable() { String.format( "Number of rows migrated %s does not equal the number of input rows %s...", totalRowsMigrated, rowCount)); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocode/RemoveAspectV2TableStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocode/RemoveAspectV2TableStep.java index 6180573d902d22..39346fa09d2319 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocode/RemoveAspectV2TableStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocode/RemoveAspectV2TableStep.java @@ -4,6 +4,7 @@ import com.linkedin.datahub.upgrade.UpgradeStep; import com.linkedin.datahub.upgrade.UpgradeStepResult; import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; +import com.linkedin.upgrade.DataHubUpgradeState; import io.ebean.Database; import java.util.function.Function; @@ -26,7 +27,7 @@ public Function executable() { return (context) -> { context.report().addLine("Cleanup requested. Dropping metadata_aspect_v2"); _server.execute(_server.sqlUpdate("DROP TABLE IF EXISTS metadata_aspect_v2")); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocode/UpgradeQualificationStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocode/UpgradeQualificationStep.java index d22af9d2924003..33de9f842a3aed 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocode/UpgradeQualificationStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocode/UpgradeQualificationStep.java @@ -5,6 +5,7 @@ import com.linkedin.datahub.upgrade.UpgradeStepResult; import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; import com.linkedin.metadata.entity.ebean.AspectStorageValidationUtil; +import com.linkedin.upgrade.DataHubUpgradeState; import io.ebean.Database; import java.util.function.Function; @@ -31,22 +32,22 @@ public Function executable() { return (context) -> { if (context.parsedArgs().containsKey(NoCodeUpgrade.FORCE_UPGRADE_ARG_NAME)) { context.report().addLine("Forced upgrade detected. Proceeding with upgrade..."); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); } try { if (isQualified(_server, context)) { // Qualified. context.report().addLine("Found qualified upgrade candidate. Proceeding with upgrade..."); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); } // Unqualified (Table already exists) context.report().addLine("Failed to qualify upgrade candidate. Aborting the upgrade..."); return new DefaultUpgradeStepResult( - id(), UpgradeStepResult.Result.SUCCEEDED, UpgradeStepResult.Action.ABORT); + id(), DataHubUpgradeState.SUCCEEDED, UpgradeStepResult.Action.ABORT); } catch (Exception e) { context.report().addLine("Failed to check if metadata_aspect_v2 table exists", e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } }; } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocodecleanup/DeleteAspectTableStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocodecleanup/DeleteAspectTableStep.java index ba0a0124545e9d..f310c65375fb3b 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocodecleanup/DeleteAspectTableStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocodecleanup/DeleteAspectTableStep.java @@ -4,6 +4,7 @@ import com.linkedin.datahub.upgrade.UpgradeStep; import com.linkedin.datahub.upgrade.UpgradeStepResult; import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; +import com.linkedin.upgrade.DataHubUpgradeState; import io.ebean.Database; import java.util.function.Function; @@ -33,9 +34,9 @@ public Function executable() { _server.execute(_server.sqlUpdate("DROP TABLE IF EXISTS metadata_aspect;")); } catch (Exception e) { context.report().addLine("Failed to delete data from legacy table metadata_aspect", e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocodecleanup/DeleteLegacyGraphRelationshipsStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocodecleanup/DeleteLegacyGraphRelationshipsStep.java index 5066e05f8bf5a1..47da1da8396430 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocodecleanup/DeleteLegacyGraphRelationshipsStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocodecleanup/DeleteLegacyGraphRelationshipsStep.java @@ -6,6 +6,7 @@ import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; import com.linkedin.metadata.graph.GraphService; import com.linkedin.metadata.graph.neo4j.Neo4jGraphService; +import com.linkedin.upgrade.DataHubUpgradeState; import java.util.function.Function; import lombok.extern.slf4j.Slf4j; @@ -42,9 +43,9 @@ public Function executable() { } } catch (Exception e) { context.report().addLine("Failed to delete legacy data from graph", e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocodecleanup/DeleteLegacySearchIndicesStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocodecleanup/DeleteLegacySearchIndicesStep.java index 05656373377b93..33ace43fee8b2a 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocodecleanup/DeleteLegacySearchIndicesStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocodecleanup/DeleteLegacySearchIndicesStep.java @@ -5,6 +5,7 @@ import com.linkedin.datahub.upgrade.UpgradeStepResult; import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; import com.linkedin.metadata.utils.elasticsearch.IndexConvention; +import com.linkedin.upgrade.DataHubUpgradeState; import java.util.function.Function; import lombok.RequiredArgsConstructor; import org.opensearch.action.admin.indices.delete.DeleteIndexRequest; @@ -43,9 +44,9 @@ public Function executable() { _searchClient.indices().delete(request, RequestOptions.DEFAULT); } catch (Exception e) { context.report().addLine("Failed to delete legacy search index: %s", e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocodecleanup/NoCodeUpgradeQualificationStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocodecleanup/NoCodeUpgradeQualificationStep.java index 15c7584532e2ca..d8284fe47f9390 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocodecleanup/NoCodeUpgradeQualificationStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/nocodecleanup/NoCodeUpgradeQualificationStep.java @@ -5,6 +5,7 @@ import com.linkedin.datahub.upgrade.UpgradeStepResult; import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; import com.linkedin.metadata.entity.ebean.AspectStorageValidationUtil; +import com.linkedin.upgrade.DataHubUpgradeState; import io.ebean.Database; import java.util.function.Function; @@ -36,15 +37,15 @@ public Function executable() { .report() .addLine("You have not successfully migrated yet. Aborting the cleanup..."); return new DefaultUpgradeStepResult( - id(), UpgradeStepResult.Result.SUCCEEDED, UpgradeStepResult.Action.ABORT); + id(), DataHubUpgradeState.SUCCEEDED, UpgradeStepResult.Action.ABORT); } else { // Qualified. context.report().addLine("Found qualified upgrade candidate. Proceeding with upgrade..."); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); } } catch (Exception e) { context.report().addLine("Failed to check if metadata_aspect_v2 table exists: %s", e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } }; } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/removeunknownaspects/RemoveClientIdAspectStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/removeunknownaspects/RemoveClientIdAspectStep.java index 6054599aa843c1..16b78a8dc8c6b3 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/removeunknownaspects/RemoveClientIdAspectStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/removeunknownaspects/RemoveClientIdAspectStep.java @@ -6,6 +6,7 @@ import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; import com.linkedin.gms.factory.telemetry.TelemetryUtils; import com.linkedin.metadata.entity.EntityService; +import com.linkedin.upgrade.DataHubUpgradeState; import java.util.HashMap; import java.util.function.Function; import lombok.RequiredArgsConstructor; @@ -38,8 +39,7 @@ public Function executable() { INVALID_CLIENT_ID_ASPECT, new HashMap<>(), true); - return (UpgradeStepResult) - new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return (UpgradeStepResult) new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/restorebackup/ClearAspectV2TableStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/restorebackup/ClearAspectV2TableStep.java index addf6dcb89c1ae..febc1bec6fe266 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/restorebackup/ClearAspectV2TableStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/restorebackup/ClearAspectV2TableStep.java @@ -5,6 +5,7 @@ import com.linkedin.datahub.upgrade.UpgradeStepResult; import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; import com.linkedin.metadata.entity.ebean.EbeanAspectV2; +import com.linkedin.upgrade.DataHubUpgradeState; import io.ebean.Database; import java.util.function.Function; @@ -26,7 +27,7 @@ public String id() { public Function executable() { return (context) -> { _server.find(EbeanAspectV2.class).delete(); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/restorebackup/RestoreStorageStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/restorebackup/RestoreStorageStep.java index eb0b24acc1ac37..4d53b603c1eaff 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/restorebackup/RestoreStorageStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/restorebackup/RestoreStorageStep.java @@ -20,6 +20,7 @@ import com.linkedin.metadata.models.AspectSpec; import com.linkedin.metadata.models.EntitySpec; import com.linkedin.metadata.models.registry.EntityRegistry; +import com.linkedin.upgrade.DataHubUpgradeState; import com.linkedin.util.Pair; import java.lang.reflect.InvocationTargetException; import java.net.URISyntaxException; @@ -89,7 +90,7 @@ public Function executable() { context.report().addLine("BACKUP_READER: " + backupReaderName.toString()); if (!backupReaderName.isPresent() || !_backupReaders.containsKey(backupReaderName.get())) { context.report().addLine("BACKUP_READER is not set or is not valid"); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } Class> clazz = @@ -134,7 +135,7 @@ public Function executable() { } context.report().addLine(String.format("Added %d rows to the aspect v2 table", numRows)); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/restoreindices/SendMAEStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/restoreindices/SendMAEStep.java index 77d988f3176f29..8e62db444a5655 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/restoreindices/SendMAEStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/restoreindices/SendMAEStep.java @@ -10,6 +10,7 @@ import com.linkedin.metadata.entity.ebean.EbeanAspectV2; import com.linkedin.metadata.entity.restoreindices.RestoreIndicesArgs; import com.linkedin.metadata.entity.restoreindices.RestoreIndicesResult; +import com.linkedin.upgrade.DataHubUpgradeState; import io.ebean.Database; import io.ebean.ExpressionList; import java.util.ArrayList; @@ -188,7 +189,7 @@ public Function executable() { context.report().addLine(String.format("Rows processed this loop %d", rowsProcessed)); start += args.batchSize; } catch (InterruptedException | ExecutionException e) { - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } } } else { @@ -219,7 +220,7 @@ public Function executable() { "Failed to send MAEs for %d rows (%.2f%% of total).", rowCount - finalJobResult.rowsMigrated, percentFailed)); } - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/AbstractMCLStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/AbstractMCLStep.java index 27e98259c8beb5..6c70aee88675c5 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/AbstractMCLStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/AbstractMCLStep.java @@ -16,6 +16,7 @@ import com.linkedin.metadata.entity.ebean.PartitionedStream; import com.linkedin.metadata.entity.restoreindices.RestoreIndicesArgs; import com.linkedin.metadata.utils.AuditStampUtils; +import com.linkedin.upgrade.DataHubUpgradeState; import com.linkedin.util.Pair; import io.datahubproject.metadata.context.OperationContext; import java.util.List; @@ -134,7 +135,7 @@ public Function executable() { BootstrapStep.setUpgradeResult(opContext, getUpgradeIdUrn(), entityService); context.report().addLine("State updated: " + getUpgradeIdUrn()); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/browsepaths/BackfillBrowsePathsV2Step.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/browsepaths/BackfillBrowsePathsV2Step.java index a1d559d05ad2fb..e6213a164febf7 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/browsepaths/BackfillBrowsePathsV2Step.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/browsepaths/BackfillBrowsePathsV2Step.java @@ -30,6 +30,7 @@ import com.linkedin.metadata.search.SearchService; import com.linkedin.metadata.utils.GenericRecordUtils; import com.linkedin.mxe.MetadataChangeProposal; +import com.linkedin.upgrade.DataHubUpgradeState; import io.datahubproject.metadata.context.OperationContext; import java.util.Set; import java.util.function.Function; @@ -98,7 +99,7 @@ public Function executable() { BootstrapStep.setUpgradeResult(context.opContext(), UPGRADE_ID_URN, entityService); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/BuildIndicesPostStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/BuildIndicesPostStep.java index 09f65c84480279..c7e59998860c17 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/BuildIndicesPostStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/BuildIndicesPostStep.java @@ -14,6 +14,7 @@ import com.linkedin.metadata.search.elasticsearch.indexbuilder.ReindexConfig; import com.linkedin.metadata.shared.ElasticSearchIndexed; import com.linkedin.structured.StructuredPropertyDefinition; +import com.linkedin.upgrade.DataHubUpgradeState; import com.linkedin.util.Pair; import java.util.List; import java.util.Map; @@ -86,14 +87,14 @@ public Function executable() { log.error( "Partial index settings update, some indices may still be blocking writes." + " Please fix the error and rerun the BuildIndices upgrade job."); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } } } catch (Exception e) { log.error("BuildIndicesPostStep failed.", e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/BuildIndicesPreStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/BuildIndicesPreStep.java index 983e7f0c97f38b..bd56042a1ff16d 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/BuildIndicesPreStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/BuildIndicesPreStep.java @@ -15,6 +15,7 @@ import com.linkedin.metadata.search.elasticsearch.indexbuilder.ReindexConfig; import com.linkedin.metadata.shared.ElasticSearchIndexed; import com.linkedin.structured.StructuredPropertyDefinition; +import com.linkedin.upgrade.DataHubUpgradeState; import com.linkedin.util.Pair; import java.io.IOException; import java.util.List; @@ -69,7 +70,7 @@ public Function executable() { log.error( "Partial index settings update, some indices may still be blocking writes." + " Please fix the error and re-run the BuildIndices upgrade job."); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } // Clone indices @@ -87,15 +88,15 @@ public Function executable() { log.error( "Partial index settings update, cloned indices may need to be cleaned up: {}", clonedName); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } } } } catch (Exception e) { log.error("BuildIndicesPreStep failed.", e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/BuildIndicesStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/BuildIndicesStep.java index 5cf370162a3125..0aefc078ffdcba 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/BuildIndicesStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/BuildIndicesStep.java @@ -7,6 +7,7 @@ import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; import com.linkedin.metadata.shared.ElasticSearchIndexed; import com.linkedin.structured.StructuredPropertyDefinition; +import com.linkedin.upgrade.DataHubUpgradeState; import com.linkedin.util.Pair; import java.util.List; import java.util.Set; @@ -40,9 +41,9 @@ public Function executable() { } } catch (Exception e) { log.error("BuildIndicesStep failed.", e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/CleanIndicesStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/CleanIndicesStep.java index fd5592c4ead25e..63b23fefceaf98 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/CleanIndicesStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/CleanIndicesStep.java @@ -10,6 +10,7 @@ import com.linkedin.metadata.search.elasticsearch.indexbuilder.ESIndexBuilder; import com.linkedin.metadata.shared.ElasticSearchIndexed; import com.linkedin.structured.StructuredPropertyDefinition; +import com.linkedin.upgrade.DataHubUpgradeState; import com.linkedin.util.Pair; import java.util.List; import java.util.Set; @@ -54,9 +55,9 @@ public Function executable() { reindexConfig -> ESIndexBuilder.cleanIndex(searchClient, esConfig, reindexConfig)); } catch (Exception e) { log.error("CleanUpIndicesStep failed.", e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/DataHubStartupStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/DataHubStartupStep.java index d2b5965a3109ce..1d83810580cf55 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/DataHubStartupStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/elasticsearch/steps/DataHubStartupStep.java @@ -6,6 +6,7 @@ import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; import com.linkedin.metadata.dao.producer.KafkaEventProducer; import com.linkedin.mxe.DataHubUpgradeHistoryEvent; +import com.linkedin.upgrade.DataHubUpgradeState; import java.util.function.Function; import lombok.RequiredArgsConstructor; import lombok.extern.slf4j.Slf4j; @@ -36,9 +37,9 @@ public Function executable() { log.info("System Update finished for version: {}", _version); } catch (Exception e) { log.error("DataHubStartupStep failed.", e); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.FAILED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.FAILED); } - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/policyfields/BackfillPolicyFieldsStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/policyfields/BackfillPolicyFieldsStep.java index c65a45aefc357f..ad28e6b6382d45 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/policyfields/BackfillPolicyFieldsStep.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/policyfields/BackfillPolicyFieldsStep.java @@ -27,6 +27,7 @@ import com.linkedin.metadata.search.SearchEntity; import com.linkedin.metadata.search.SearchService; import com.linkedin.policy.DataHubPolicyInfo; +import com.linkedin.upgrade.DataHubUpgradeState; import io.datahubproject.metadata.context.OperationContext; import java.net.URISyntaxException; import java.util.Collections; @@ -90,7 +91,7 @@ public Function executable() { BootstrapStep.setUpgradeResult(context.opContext(), UPGRADE_ID_URN, entityService); - return new DefaultUpgradeStepResult(id(), UpgradeStepResult.Result.SUCCEEDED); + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); }; } diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/schemafield/GenerateSchemaFieldsFromSchemaMetadata.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/schemafield/GenerateSchemaFieldsFromSchemaMetadata.java new file mode 100644 index 00000000000000..20bc65bf15daee --- /dev/null +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/schemafield/GenerateSchemaFieldsFromSchemaMetadata.java @@ -0,0 +1,48 @@ +package com.linkedin.datahub.upgrade.system.schemafield; + +import com.google.common.collect.ImmutableList; +import com.linkedin.datahub.upgrade.UpgradeStep; +import com.linkedin.datahub.upgrade.system.NonBlockingSystemUpgrade; +import com.linkedin.metadata.entity.AspectDao; +import com.linkedin.metadata.entity.EntityService; +import io.datahubproject.metadata.context.OperationContext; +import java.util.List; +import javax.annotation.Nonnull; +import lombok.extern.slf4j.Slf4j; + +/** + * A {@link NonBlockingSystemUpgrade} upgrade job that generates schema fields from schema metadata. + */ +@Slf4j +public class GenerateSchemaFieldsFromSchemaMetadata implements NonBlockingSystemUpgrade { + + private final List _steps; + + public GenerateSchemaFieldsFromSchemaMetadata( + @Nonnull OperationContext opContext, + EntityService entityService, + AspectDao aspectDao, + boolean enabled, + Integer batchSize, + Integer batchDelayMs, + Integer limit) { + if (enabled) { + _steps = + ImmutableList.of( + new GenerateSchemaFieldsFromSchemaMetadataStep( + opContext, entityService, aspectDao, batchSize, batchDelayMs, limit)); + } else { + _steps = ImmutableList.of(); + } + } + + @Override + public String id() { + return this.getClass().getName(); + } + + @Override + public List steps() { + return _steps; + } +} diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/schemafield/GenerateSchemaFieldsFromSchemaMetadataStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/schemafield/GenerateSchemaFieldsFromSchemaMetadataStep.java new file mode 100644 index 00000000000000..eece83f4ab713e --- /dev/null +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/schemafield/GenerateSchemaFieldsFromSchemaMetadataStep.java @@ -0,0 +1,256 @@ +package com.linkedin.datahub.upgrade.system.schemafield; + +import static com.linkedin.metadata.Constants.APP_SOURCE; +import static com.linkedin.metadata.Constants.DATASET_ENTITY_NAME; +import static com.linkedin.metadata.Constants.SCHEMA_METADATA_ASPECT_NAME; +import static com.linkedin.metadata.Constants.STATUS_ASPECT_NAME; +import static com.linkedin.metadata.Constants.SYSTEM_UPDATE_SOURCE; + +import com.google.common.annotations.VisibleForTesting; +import com.linkedin.common.urn.Urn; +import com.linkedin.data.template.StringMap; +import com.linkedin.datahub.upgrade.UpgradeContext; +import com.linkedin.datahub.upgrade.UpgradeStep; +import com.linkedin.datahub.upgrade.UpgradeStepResult; +import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; +import com.linkedin.events.metadata.ChangeType; +import com.linkedin.metadata.aspect.ReadItem; +import com.linkedin.metadata.aspect.batch.AspectsBatch; +import com.linkedin.metadata.boot.BootstrapStep; +import com.linkedin.metadata.entity.AspectDao; +import com.linkedin.metadata.entity.EntityService; +import com.linkedin.metadata.entity.EntityUtils; +import com.linkedin.metadata.entity.ebean.EbeanAspectV2; +import com.linkedin.metadata.entity.ebean.PartitionedStream; +import com.linkedin.metadata.entity.ebean.batch.AspectsBatchImpl; +import com.linkedin.metadata.entity.ebean.batch.ChangeItemImpl; +import com.linkedin.metadata.entity.restoreindices.RestoreIndicesArgs; +import com.linkedin.mxe.SystemMetadata; +import com.linkedin.upgrade.DataHubUpgradeResult; +import com.linkedin.upgrade.DataHubUpgradeState; +import io.datahubproject.metadata.context.OperationContext; +import java.util.List; +import java.util.Map; +import java.util.Optional; +import java.util.Set; +import java.util.function.Function; +import java.util.stream.Collectors; +import lombok.extern.slf4j.Slf4j; +import org.jetbrains.annotations.Nullable; + +/** + * The `GenerateSchemaFieldsFromSchemaMetadataStep` class is an implementation of the `UpgradeStep` + * interface. This class is responsible for generating schema fields from schema metadata during an + * upgrade process. + * + *

The step performs the following actions: 1. Initializes with provided operation context, + * entity service, and aspect DAO. 2. Provides a unique identifier for the upgrade step. 3. + * Determines if the upgrade should be skipped based on the environment variable. 4. Executes the + * upgrade step which involves streaming aspects in batches, processing them, and updating schema + * fields. + * + *

This class utilizes various metadata and entity services to perform its operations, and + * includes configuration parameters such as batch size, delay between batches, and limits. + * + *

Environment Variables: - `SKIP_GENERATE_SCHEMA_FIELDS_FROM_SCHEMA_METADATA`: If set to `true`, + * the upgrade step is skipped. + * + *

Note: Schema Fields are generated with a status aspect to indicate presence of the field. No + * tags, documentation or other aspects are generated. We will write an upgrade to this job to + * generate the other aspects in the future (v2). + */ +@Slf4j +public class GenerateSchemaFieldsFromSchemaMetadataStep implements UpgradeStep { + private static final String LAST_URN_KEY = "lastUrn"; + private static final List REQUIRED_ASPECTS = + List.of(SCHEMA_METADATA_ASPECT_NAME, STATUS_ASPECT_NAME); + + private final OperationContext opContext; + private final EntityService entityService; + private final AspectDao aspectDao; + + private final int batchSize; + private final int batchDelayMs; + private final int limit; + + public GenerateSchemaFieldsFromSchemaMetadataStep( + OperationContext opContext, + EntityService entityService, + AspectDao aspectDao, + Integer batchSize, + Integer batchDelayMs, + Integer limit) { + this.opContext = opContext; + this.entityService = entityService; + this.aspectDao = aspectDao; + this.batchSize = batchSize; + this.batchDelayMs = batchDelayMs; + this.limit = limit; + log.info("GenerateSchemaFieldsFromSchemaMetadataStep initialized"); + } + + @Override + public String id() { + return "schema-field-from-schema-metadata-v1"; + } + + @VisibleForTesting + @Nullable + public String getUrnLike() { + return "urn:li:" + DATASET_ENTITY_NAME + ":%"; + } + + /** + * Returns whether the upgrade should be skipped. Uses previous run history or the environment + * variable SKIP_GENERATE_SCHEMA_FIELDS_FROM_SCHEMA_METADATA to determine whether to skip. + */ + public boolean skip(UpgradeContext context) { + if (Boolean.parseBoolean(System.getenv("SKIP_GENERATE_SCHEMA_FIELDS_FROM_SCHEMA_METADATA"))) { + log.info( + "Environment variable SKIP_GENERATE_SCHEMA_FIELDS_FROM_SCHEMA_METADATA is set to true. Skipping."); + return true; + } + + Optional prevResult = + context.upgrade().getUpgradeResult(opContext, getUpgradeIdUrn(), entityService); + + return prevResult + .filter( + result -> + DataHubUpgradeState.SUCCEEDED.equals(result.getState()) + || DataHubUpgradeState.ABORTED.equals(result.getState())) + .isPresent(); + } + + protected Urn getUpgradeIdUrn() { + return BootstrapStep.getUpgradeUrn(id()); + } + + @Override + public Function executable() { + log.info("Starting GenerateSchemaFieldsFromSchemaMetadataStep"); + return (context) -> { + // Resume state + Optional prevResult = + context.upgrade().getUpgradeResult(opContext, getUpgradeIdUrn(), entityService); + String resumeUrn = + prevResult + .filter( + result -> + DataHubUpgradeState.IN_PROGRESS.equals(result.getState()) + && result.getResult() != null + && result.getResult().containsKey(LAST_URN_KEY)) + .map(result -> result.getResult().get(LAST_URN_KEY)) + .orElse(null); + if (resumeUrn != null) { + log.info("{}: Resuming from URN: {}", getUpgradeIdUrn(), resumeUrn); + } + + // re-using for configuring the sql scan + RestoreIndicesArgs args = + new RestoreIndicesArgs() + .aspectNames(REQUIRED_ASPECTS) + .batchSize(batchSize) + .lastUrn(resumeUrn) + .urnBasedPagination(resumeUrn != null) + .limit(limit); + + if (getUrnLike() != null) { + args = args.urnLike(getUrnLike()); + } + + try (PartitionedStream stream = aspectDao.streamAspectBatches(args)) { + stream + .partition(args.batchSize) + .forEach( + batch -> { + log.info("Processing batch of size {}.", batchSize); + + AspectsBatch aspectsBatch = + AspectsBatchImpl.builder() + .retrieverContext(opContext.getRetrieverContext().get()) + .items( + batch + .flatMap( + ebeanAspectV2 -> + EntityUtils.toSystemAspectFromEbeanAspects( + opContext.getRetrieverContext().get(), + Set.of(ebeanAspectV2)) + .stream()) + .map( + systemAspect -> + ChangeItemImpl.builder() + .changeType(ChangeType.UPSERT) + .urn(systemAspect.getUrn()) + .entitySpec(systemAspect.getEntitySpec()) + .aspectName(systemAspect.getAspectName()) + .aspectSpec(systemAspect.getAspectSpec()) + .recordTemplate(systemAspect.getRecordTemplate()) + .auditStamp(systemAspect.getAuditStamp()) + .systemMetadata( + withAppSource(systemAspect.getSystemMetadata())) + .build( + opContext + .getRetrieverContext() + .get() + .getAspectRetriever())) + .collect(Collectors.toList())) + .build(); + + // re-ingest the aspects to trigger side effects + entityService.ingestAspects(opContext, aspectsBatch, true, false); + + // record progress + Urn lastUrn = + aspectsBatch.getItems().stream() + .reduce((a, b) -> b) + .map(ReadItem::getUrn) + .orElse(null); + if (lastUrn != null) { + log.info("{}: Saving state. Last urn:{}", getUpgradeIdUrn(), lastUrn); + context + .upgrade() + .setUpgradeResult( + opContext, + getUpgradeIdUrn(), + entityService, + DataHubUpgradeState.IN_PROGRESS, + Map.of(LAST_URN_KEY, lastUrn.toString())); + } + + if (batchDelayMs > 0) { + log.info("Sleeping for {} ms", batchDelayMs); + try { + Thread.sleep(batchDelayMs); + } catch (InterruptedException e) { + throw new RuntimeException(e); + } + } + }); + } + + BootstrapStep.setUpgradeResult(opContext, getUpgradeIdUrn(), entityService); + context.report().addLine("State updated: " + getUpgradeIdUrn()); + + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); + }; + } + + private static SystemMetadata withAppSource(@Nullable SystemMetadata systemMetadata) { + SystemMetadata withAppSourceSystemMetadata = null; + try { + withAppSourceSystemMetadata = + systemMetadata != null + ? new SystemMetadata(systemMetadata.copy().data()) + : new SystemMetadata(); + } catch (CloneNotSupportedException e) { + throw new RuntimeException(e); + } + StringMap properties = withAppSourceSystemMetadata.getProperties(); + StringMap map = properties != null ? new StringMap(properties.data()) : new StringMap(); + map.put(APP_SOURCE, SYSTEM_UPDATE_SOURCE); + + withAppSourceSystemMetadata.setProperties(map); + return withAppSourceSystemMetadata; + } +} diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/schemafield/MigrateSchemaFieldDocIds.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/schemafield/MigrateSchemaFieldDocIds.java new file mode 100644 index 00000000000000..6cfd0d8c032ec1 --- /dev/null +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/schemafield/MigrateSchemaFieldDocIds.java @@ -0,0 +1,50 @@ +package com.linkedin.datahub.upgrade.system.schemafield; + +import com.google.common.collect.ImmutableList; +import com.linkedin.datahub.upgrade.UpgradeStep; +import com.linkedin.datahub.upgrade.system.NonBlockingSystemUpgrade; +import com.linkedin.gms.factory.search.BaseElasticSearchComponentsFactory; +import com.linkedin.metadata.entity.EntityService; +import io.datahubproject.metadata.context.OperationContext; +import java.util.List; +import javax.annotation.Nonnull; +import lombok.extern.slf4j.Slf4j; + +/** Migrate from URN document ids to hash based ids */ +@Slf4j +public class MigrateSchemaFieldDocIds implements NonBlockingSystemUpgrade { + private final List _steps; + + public MigrateSchemaFieldDocIds( + @Nonnull OperationContext opContext, + BaseElasticSearchComponentsFactory.BaseElasticSearchComponents elasticSearchComponents, + EntityService entityService, + boolean enabled, + Integer batchSize, + Integer batchDelayMs, + Integer limit) { + if (enabled) { + _steps = + ImmutableList.of( + new MigrateSchemaFieldDocIdsStep( + opContext, + elasticSearchComponents, + entityService, + batchSize, + batchDelayMs, + limit)); + } else { + _steps = ImmutableList.of(); + } + } + + @Override + public String id() { + return this.getClass().getName(); + } + + @Override + public List steps() { + return _steps; + } +} diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/schemafield/MigrateSchemaFieldDocIdsStep.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/schemafield/MigrateSchemaFieldDocIdsStep.java new file mode 100644 index 00000000000000..ab35b42bcc8481 --- /dev/null +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/system/schemafield/MigrateSchemaFieldDocIdsStep.java @@ -0,0 +1,291 @@ +package com.linkedin.datahub.upgrade.system.schemafield; + +import static com.linkedin.metadata.Constants.SCHEMA_FIELD_ENTITY_NAME; +import static com.linkedin.metadata.utils.GenericRecordUtils.entityResponseToSystemAspectMap; + +import com.linkedin.common.urn.Urn; +import com.linkedin.common.urn.UrnUtils; +import com.linkedin.datahub.upgrade.UpgradeContext; +import com.linkedin.datahub.upgrade.UpgradeStep; +import com.linkedin.datahub.upgrade.UpgradeStepResult; +import com.linkedin.datahub.upgrade.impl.DefaultUpgradeStepResult; +import com.linkedin.events.metadata.ChangeType; +import com.linkedin.gms.factory.search.BaseElasticSearchComponentsFactory; +import com.linkedin.metadata.aspect.SystemAspect; +import com.linkedin.metadata.boot.BootstrapStep; +import com.linkedin.metadata.entity.EntityService; +import com.linkedin.metadata.models.registry.EntityRegistry; +import com.linkedin.metadata.utils.AuditStampUtils; +import com.linkedin.upgrade.DataHubUpgradeResult; +import com.linkedin.upgrade.DataHubUpgradeState; +import io.datahubproject.metadata.context.OperationContext; +import java.io.IOException; +import java.net.URISyntaxException; +import java.util.Arrays; +import java.util.Map; +import java.util.Optional; +import java.util.Set; +import java.util.concurrent.ExecutionException; +import java.util.concurrent.Future; +import java.util.function.Function; +import java.util.stream.Collectors; +import lombok.extern.slf4j.Slf4j; +import org.opensearch.action.bulk.BulkProcessor; +import org.opensearch.action.bulk.BulkRequest; +import org.opensearch.action.bulk.BulkResponse; +import org.opensearch.action.delete.DeleteRequest; +import org.opensearch.action.search.SearchRequest; +import org.opensearch.action.search.SearchResponse; +import org.opensearch.action.search.SearchScrollRequest; +import org.opensearch.client.RequestOptions; +import org.opensearch.client.RestHighLevelClient; +import org.opensearch.common.unit.TimeValue; +import org.opensearch.index.query.QueryBuilder; +import org.opensearch.index.query.QueryBuilders; +import org.opensearch.script.Script; +import org.opensearch.search.Scroll; +import org.opensearch.search.SearchHit; +import org.opensearch.search.builder.SearchSourceBuilder; +import org.opensearch.search.sort.SortOrder; + +/** + * Performs a migration from one document id convention to another. + * + *

This step identifies documents using the old convention, if any, and generates MCLs for + * aspects for updating the data in the new document. + * + *

Finally, a DELETE is executed on the legacy document id. + */ +@Slf4j +public class MigrateSchemaFieldDocIdsStep implements UpgradeStep { + + private final OperationContext opContext; + private final EntityRegistry entityRegistry; + private final RestHighLevelClient elasticsearchClient; + private final BulkProcessor bulkProcessor; + private final String indexName; + private final EntityService entityService; + private final Scroll scroll = new Scroll(TimeValue.timeValueMinutes(5L)); + private final int batchSize; + private final int batchDelayMs; + private final int limit; + + public MigrateSchemaFieldDocIdsStep( + OperationContext opContext, + BaseElasticSearchComponentsFactory.BaseElasticSearchComponents elasticSearchComponents, + EntityService entityService, + int batchSize, + int batchDelayMs, + int limit) { + this.opContext = opContext; + this.entityRegistry = opContext.getEntityRegistry(); + this.elasticsearchClient = elasticSearchComponents.getSearchClient(); + this.entityService = entityService; + this.batchSize = batchSize; + this.batchDelayMs = batchDelayMs; + this.limit = limit; + this.indexName = + elasticSearchComponents.getIndexConvention().getEntityIndexName(SCHEMA_FIELD_ENTITY_NAME); + this.bulkProcessor = buildBuildProcessor(); + log.info("MigrateSchemaFieldDocIdsStep initialized"); + } + + @Override + public String id() { + return "schema-field-doc-id-v1"; + } + + /** + * Returns whether the upgrade should be skipped. Uses previous run history or the environment + * variable SKIP_MIGRATE_SCHEMA_FIELDS_DOC_ID to determine whether to skip. + */ + public boolean skip(UpgradeContext context) { + if (Boolean.parseBoolean(System.getenv("SKIP_MIGRATE_SCHEMA_FIELDS_DOC_ID"))) { + log.info("Environment variable SKIP_MIGRATE_SCHEMA_FIELDS_DOC_ID is set to true. Skipping."); + return true; + } + + Optional prevResult = + context.upgrade().getUpgradeResult(opContext, getUpgradeIdUrn(), entityService); + + return prevResult + .filter( + result -> + DataHubUpgradeState.SUCCEEDED.equals(result.getState()) + || DataHubUpgradeState.ABORTED.equals(result.getState())) + .isPresent(); + } + + protected Urn getUpgradeIdUrn() { + return BootstrapStep.getUpgradeUrn(id()); + } + + @Override + public Function executable() { + return (context) -> { + final SearchRequest searchRequest = buildSearchRequest(); + String scrollId = null; + int migratedCount = 0; + + try { + do { + log.info( + "Upgrading batch of schemaFields {}-{}", migratedCount, migratedCount + batchSize); + scrollId = updateDocId(searchRequest, scrollId); + migratedCount += batchSize; + + if (limit > 0 && migratedCount >= limit) { + log.info("Exiting early due to limit."); + break; + } + + if (batchDelayMs > 0) { + log.info("Sleeping for {} ms", batchDelayMs); + try { + Thread.sleep(batchDelayMs); + } catch (InterruptedException e) { + throw new RuntimeException(e); + } + } + } while (scrollId != null); + } catch (Exception e) { + throw new RuntimeException(e); + } finally { + bulkProcessor.flush(); + } + + BootstrapStep.setUpgradeResult(context.opContext(), getUpgradeIdUrn(), entityService); + + return new DefaultUpgradeStepResult(id(), DataHubUpgradeState.SUCCEEDED); + }; + } + + private BulkProcessor buildBuildProcessor() { + return BulkProcessor.builder( + (request, bulkListener) -> + elasticsearchClient.bulkAsync(request, RequestOptions.DEFAULT, bulkListener), + new BulkProcessor.Listener() { + @Override + public void beforeBulk(long executionId, BulkRequest request) { + log.debug("Deleting {} legacy schemaField documents", request.numberOfActions()); + } + + @Override + public void afterBulk(long executionId, BulkRequest request, BulkResponse response) { + log.debug( + "Delete executed {} failures", response.hasFailures() ? "with" : "without"); + } + + @Override + public void afterBulk(long executionId, BulkRequest request, Throwable failure) { + log.warn("Error while executing legacy schemaField documents", failure); + } + }) + .setBulkActions(batchSize) + .build(); + } + + private SearchRequest buildSearchRequest() { + Script oldDocumentIdQuery = + new Script( + Script.DEFAULT_SCRIPT_TYPE, + "painless", + "doc['_id'][0].indexOf('urn%3Ali%3AschemaField%3A%28urn%3Ali%3Adataset%3A') > -1", + Map.of()); + QueryBuilder queryBuilder = QueryBuilders.scriptQuery(oldDocumentIdQuery); + + SearchRequest searchRequest = new SearchRequest(indexName); + searchRequest.scroll(scroll); + SearchSourceBuilder searchSourceBuilder = new SearchSourceBuilder(); + searchSourceBuilder.query(queryBuilder); + searchSourceBuilder.size(batchSize); + searchSourceBuilder.sort("urn", SortOrder.ASC); + searchRequest.source(searchSourceBuilder); + + return searchRequest; + } + + private String updateDocId(final SearchRequest searchRequest, final String scrollId) + throws IOException, URISyntaxException { + final SearchResponse searchResponse; + + if (scrollId == null) { + searchResponse = elasticsearchClient.search(searchRequest, RequestOptions.DEFAULT); + } else { + SearchScrollRequest scrollRequest = new SearchScrollRequest(scrollId); + scrollRequest.scroll(scroll); + searchResponse = elasticsearchClient.scroll(scrollRequest, RequestOptions.DEFAULT); + } + + final SearchHit[] searchHits = searchResponse.getHits().getHits(); + final String nextScrollId = searchResponse.getScrollId(); + + if (searchHits.length > 0) { + Set documentIds = + Arrays.stream(searchHits).map(SearchHit::getId).collect(Collectors.toSet()); + Set batchUrns = + Arrays.stream(searchHits) + .map(hit -> hit.getSourceAsMap().get("urn").toString()) + .map(UrnUtils::getUrn) + .collect(Collectors.toSet()); + + log.info("Sending MCLs for {} entities", batchUrns.size()); + emitMCLs(batchUrns); + log.info("Removing old document ids for {} documents", documentIds.size()); + deleteDocumentIds(documentIds); + + return nextScrollId; + } + + return null; + } + + private void emitMCLs(Set batchUrns) throws URISyntaxException { + Set batchAspects = + entityResponseToSystemAspectMap( + entityService.getEntitiesV2( + opContext, + SCHEMA_FIELD_ENTITY_NAME, + batchUrns, + opContext.getEntityAspectNames(SCHEMA_FIELD_ENTITY_NAME), + false), + entityRegistry) + .values() + .stream() + .flatMap(m -> m.values().stream()) + .collect(Collectors.toSet()); + + Set> futures = + batchAspects.stream() + .map( + systemAspect -> + entityService + .alwaysProduceMCLAsync( + opContext, + systemAspect.getUrn(), + systemAspect.getUrn().getEntityType(), + systemAspect.getAspectName(), + systemAspect.getAspectSpec(), + null, + systemAspect.getRecordTemplate(), + null, + systemAspect.getSystemMetadata(), + AuditStampUtils.createDefaultAuditStamp(), + ChangeType.UPSERT) + .getFirst()) + .collect(Collectors.toSet()); + + futures.forEach( + f -> { + try { + f.get(); + } catch (InterruptedException | ExecutionException e) { + throw new RuntimeException(e); + } + }); + } + + private void deleteDocumentIds(Set documentIds) { + documentIds.forEach(docId -> bulkProcessor.add(new DeleteRequest(indexName, docId))); + } +} diff --git a/datahub-upgrade/src/test/java/com/linkedin/datahub/upgrade/DatahubUpgradeNoSchemaRegistryTest.java b/datahub-upgrade/src/test/java/com/linkedin/datahub/upgrade/DatahubUpgradeNoSchemaRegistryTest.java index 8c9b72b0d88e5e..ffc5d8d765f659 100644 --- a/datahub-upgrade/src/test/java/com/linkedin/datahub/upgrade/DatahubUpgradeNoSchemaRegistryTest.java +++ b/datahub-upgrade/src/test/java/com/linkedin/datahub/upgrade/DatahubUpgradeNoSchemaRegistryTest.java @@ -13,6 +13,7 @@ import com.linkedin.metadata.dao.producer.KafkaEventProducer; import com.linkedin.metadata.entity.EntityServiceImpl; import com.linkedin.mxe.Topics; +import com.linkedin.upgrade.DataHubUpgradeState; import io.confluent.kafka.schemaregistry.client.SchemaRegistryClient; import io.confluent.kafka.schemaregistry.client.rest.exceptions.RestClientException; import io.datahubproject.metadata.context.OperationContext; @@ -79,7 +80,7 @@ public void testSystemUpdateKafkaProducerOverride() throws RestClientException, @Test public void testSystemUpdateSend() { - UpgradeStepResult.Result result = + DataHubUpgradeState result = systemUpdate.steps().stream() .filter(s -> s.id().equals("DataHubStartupStep")) .findFirst() diff --git a/datahub-upgrade/src/test/java/com/linkedin/datahub/upgrade/schemafield/GenerateSchemaFieldsFromSchemaMetadataStepTest.java b/datahub-upgrade/src/test/java/com/linkedin/datahub/upgrade/schemafield/GenerateSchemaFieldsFromSchemaMetadataStepTest.java new file mode 100644 index 00000000000000..3a2728b4e1d3d6 --- /dev/null +++ b/datahub-upgrade/src/test/java/com/linkedin/datahub/upgrade/schemafield/GenerateSchemaFieldsFromSchemaMetadataStepTest.java @@ -0,0 +1,110 @@ +package com.linkedin.datahub.upgrade.schemafield; + +import static org.junit.jupiter.api.Assertions.assertEquals; +import static org.junit.jupiter.api.Assertions.assertFalse; +import static org.junit.jupiter.api.Assertions.assertTrue; +import static org.mockito.Mockito.any; +import static org.mockito.Mockito.anyInt; +import static org.mockito.Mockito.mock; +import static org.mockito.Mockito.verify; +import static org.mockito.Mockito.when; + +import com.linkedin.datahub.upgrade.UpgradeContext; +import com.linkedin.datahub.upgrade.UpgradeStepResult; +import com.linkedin.datahub.upgrade.system.schemafield.GenerateSchemaFieldsFromSchemaMetadataStep; +import com.linkedin.metadata.aspect.SystemAspect; +import com.linkedin.metadata.entity.AspectDao; +import com.linkedin.metadata.entity.EntityService; +import com.linkedin.metadata.entity.ebean.EbeanAspectV2; +import com.linkedin.metadata.entity.ebean.PartitionedStream; +import com.linkedin.metadata.entity.restoreindices.RestoreIndicesArgs; +import com.linkedin.schema.SchemaMetadata; +import com.linkedin.upgrade.DataHubUpgradeState; +import io.datahubproject.metadata.context.OperationContext; +import io.datahubproject.metadata.context.RetrieverContext; +import java.util.Optional; +import java.util.stream.Stream; +import org.junit.jupiter.api.BeforeEach; +import org.junit.jupiter.api.Test; +import org.mockito.ArgumentCaptor; +import org.mockito.Mock; +import org.mockito.MockitoAnnotations; + +public class GenerateSchemaFieldsFromSchemaMetadataStepTest { + + @Mock private OperationContext mockOpContext; + + @Mock private EntityService mockEntityService; + + @Mock private AspectDao mockAspectDao; + + @Mock private RetrieverContext mockRetrieverContext; + + private GenerateSchemaFieldsFromSchemaMetadataStep step; + + @BeforeEach + public void setup() { + MockitoAnnotations.openMocks(this); + step = + new GenerateSchemaFieldsFromSchemaMetadataStep( + mockOpContext, mockEntityService, mockAspectDao, 10, 100, 1000); + when(mockOpContext.getRetrieverContext()).thenReturn(Optional.of(mockRetrieverContext)); + } + + /** Test to verify the correct step ID is returned. */ + @Test + public void testId() { + assertEquals("schema-field-from-schema-metadata-v1", step.id()); + } + + /** Test to verify the skip logic based on the environment variable. */ + @Test + public void testSkip() { + UpgradeContext mockContext = mock(UpgradeContext.class); + System.setProperty("SKIP_GENERATE_SCHEMA_FIELDS_FROM_SCHEMA_METADATA", "true"); + assertTrue(step.skip(mockContext)); + + System.setProperty("SKIP_GENERATE_SCHEMA_FIELDS_FROM_SCHEMA_METADATA", "false"); + assertFalse(step.skip(mockContext)); + } + + /** Test to verify the correct URN pattern is returned. */ + @Test + public void testGetUrnLike() { + assertEquals("urn:li:dataset:%", step.getUrnLike()); + } + + /** + * Test to verify the executable function processes batches correctly and returns a success + * result. + */ + @Test + public void testExecutable() { + UpgradeContext mockContext = mock(UpgradeContext.class); + + EbeanAspectV2 mockAspect = mock(EbeanAspectV2.class); + PartitionedStream mockStream = mock(PartitionedStream.class); + when(mockAspectDao.streamAspectBatches(any(RestoreIndicesArgs.class))).thenReturn(mockStream); + + when(mockStream.partition(anyInt())).thenReturn(Stream.of(Stream.of(mockAspect))); + + SystemAspect mockSystemAspect = mock(SystemAspect.class); + when(mockSystemAspect.getAspectName()).thenReturn("schemaMetadata"); + when(mockSystemAspect.getAspect(SchemaMetadata.class)).thenReturn(new SchemaMetadata()); + + // when(mockRetrieverContext.getAspectRetriever()).thenReturn(mockSystemAspect); + + ArgumentCaptor argsCaptor = + ArgumentCaptor.forClass(RestoreIndicesArgs.class); + + UpgradeStepResult result = step.executable().apply(mockContext); + assertEquals(DataHubUpgradeState.SUCCEEDED, result.result()); + + verify(mockAspectDao).streamAspectBatches(argsCaptor.capture()); + assertEquals("schemaMetadata", argsCaptor.getValue().aspectName()); + assertEquals(10, argsCaptor.getValue().batchSize()); + assertEquals(1000, argsCaptor.getValue().limit()); + } + + // Additional tests can be added to cover more scenarios and edge cases +} diff --git a/entity-registry/src/main/java/com/linkedin/metadata/aspect/batch/AspectsBatch.java b/entity-registry/src/main/java/com/linkedin/metadata/aspect/batch/AspectsBatch.java index fc4ac90dfabad8..dc7934ad5cc193 100644 --- a/entity-registry/src/main/java/com/linkedin/metadata/aspect/batch/AspectsBatch.java +++ b/entity-registry/src/main/java/com/linkedin/metadata/aspect/batch/AspectsBatch.java @@ -199,6 +199,7 @@ default Map> getNewUrnAspectsMap( static Map> merge( @Nonnull Map> a, @Nonnull Map> b) { + Map> mergedMap = new HashMap<>(); for (Map.Entry> entry : Stream.concat(a.entrySet().stream(), b.entrySet().stream()).collect(Collectors.toList())) { diff --git a/entity-registry/src/main/java/com/linkedin/metadata/aspect/batch/MCLItem.java b/entity-registry/src/main/java/com/linkedin/metadata/aspect/batch/MCLItem.java index 9fd2d6c607342f..09da0a52ff0c30 100644 --- a/entity-registry/src/main/java/com/linkedin/metadata/aspect/batch/MCLItem.java +++ b/entity-registry/src/main/java/com/linkedin/metadata/aspect/batch/MCLItem.java @@ -69,4 +69,13 @@ default ChangeType getChangeType() { default AuditStamp getAuditStamp() { return getMetadataChangeLog().getCreated(); } + + /** + * Change detection for previous and new record template + * + * @return no change detection + */ + default boolean isNoOp() { + return getPreviousRecordTemplate() == getRecordTemplate(); + } } diff --git a/li-utils/src/main/java/com/linkedin/metadata/Constants.java b/li-utils/src/main/java/com/linkedin/metadata/Constants.java index 959125be12c4c8..e085a5876a42b0 100644 --- a/li-utils/src/main/java/com/linkedin/metadata/Constants.java +++ b/li-utils/src/main/java/com/linkedin/metadata/Constants.java @@ -49,6 +49,7 @@ public class Constants { // App sources public static final String UI_SOURCE = "ui"; + public static final String SYSTEM_UPDATE_SOURCE = "systemUpdate"; /** Entities */ public static final String CORP_USER_ENTITY_NAME = "corpuser"; @@ -85,6 +86,8 @@ public class Constants { public static final String DATAHUB_ROLE_ENTITY_NAME = "dataHubRole"; public static final String POST_ENTITY_NAME = "post"; public static final String SCHEMA_FIELD_ENTITY_NAME = "schemaField"; + public static final String SCHEMA_FIELD_KEY_ASPECT = "schemaFieldKey"; + public static final String SCHEMA_FIELD_ALIASES_ASPECT = "schemaFieldAliases"; public static final String DATAHUB_STEP_STATE_ENTITY_NAME = "dataHubStepState"; public static final String DATAHUB_VIEW_ENTITY_NAME = "dataHubView"; public static final String QUERY_ENTITY_NAME = "query"; diff --git a/metadata-events/mxe-utils-avro/src/main/java/com/linkedin/metadata/EventUtils.java b/metadata-events/mxe-utils-avro/src/main/java/com/linkedin/metadata/EventUtils.java index 8e92fd70b91dc1..18005dfb7b2a5d 100644 --- a/metadata-events/mxe-utils-avro/src/main/java/com/linkedin/metadata/EventUtils.java +++ b/metadata-events/mxe-utils-avro/src/main/java/com/linkedin/metadata/EventUtils.java @@ -81,7 +81,7 @@ public class EventUtils { private static final Schema RENAMED_PE_AVRO_SCHEMA = com.linkedin.pegasus2avro.mxe.PlatformEvent.SCHEMA$; - private static final Schema RENAMED_MCP_AVRO_SCHEMA = + public static final Schema RENAMED_MCP_AVRO_SCHEMA = com.linkedin.pegasus2avro.mxe.MetadataChangeProposal.SCHEMA$; public static final Schema RENAMED_MCL_AVRO_SCHEMA = diff --git a/metadata-ingestion/tests/unit/api/entities/dataproducts/golden_dataproduct_out_upsert.json b/metadata-ingestion/tests/unit/api/entities/dataproducts/golden_dataproduct_out_upsert.json index 66bc2ce0c2a0c0..8d072030d1209b 100644 --- a/metadata-ingestion/tests/unit/api/entities/dataproducts/golden_dataproduct_out_upsert.json +++ b/metadata-ingestion/tests/unit/api/entities/dataproducts/golden_dataproduct_out_upsert.json @@ -5,8 +5,59 @@ "changeType": "PATCH", "aspectName": "dataProductProperties", "aspect": { - "value": "[{\"op\": \"add\", \"path\": \"/name\", \"value\": \"Pet of the Week Campaign\"}, {\"op\": \"add\", \"path\": \"/assets\", \"value\": [{\"destinationUrn\": \"urn:li:container:DATABASE\", \"created\": {\"time\": 1681455600000, \"actor\": \"urn:li:corpuser:datahub\", \"message\": \"yaml\"}}, {\"destinationUrn\": \"urn:li:container:SCHEMA\", \"created\": {\"time\": 1681455600000, \"actor\": \"urn:li:corpuser:datahub\", \"message\": \"yaml\"}}, {\"destinationUrn\": \"urn:li:mlFeatureTable:(urn:li:dataPlatform:feast,test_feature_table_all_feature_dtypes)\", \"created\": {\"time\": 1681455600000, \"actor\": \"urn:li:corpuser:datahub\", \"message\": \"yaml\"}}]}, {\"op\": \"add\", \"path\": \"/customProperties\", \"value\": {\"version\": \"2.0\", \"classification\": \"pii\"}}, {\"op\": \"add\", \"path\": \"/externalUrl\", \"value\": \"https://github.com/datahub-project/datahub\"}]", - "contentType": "application/json-patch+json" + "json": [ + { + "op": "add", + "path": "/name", + "value": "Pet of the Week Campaign" + }, + { + "op": "add", + "path": "/assets", + "value": [ + { + "destinationUrn": "urn:li:container:DATABASE", + "created": { + "time": 1681455600000, + "actor": "urn:li:corpuser:datahub", + "message": "yaml" + }, + "outputPort": false + }, + { + "destinationUrn": "urn:li:container:SCHEMA", + "created": { + "time": 1681455600000, + "actor": "urn:li:corpuser:datahub", + "message": "yaml" + }, + "outputPort": false + }, + { + "destinationUrn": "urn:li:mlFeatureTable:(urn:li:dataPlatform:feast,test_feature_table_all_feature_dtypes)", + "created": { + "time": 1681455600000, + "actor": "urn:li:corpuser:datahub", + "message": "yaml" + }, + "outputPort": false + } + ] + }, + { + "op": "add", + "path": "/customProperties", + "value": { + "version": "2.0", + "classification": "pii" + } + }, + { + "op": "add", + "path": "/externalUrl", + "value": "https://github.com/datahub-project/datahub" + } + ] } }, { @@ -70,6 +121,7 @@ "type": "BUSINESS_OWNER" } ], + "ownerTypes": {}, "lastModified": { "time": 0, "actor": "urn:li:corpuser:unknown" diff --git a/metadata-io/build.gradle b/metadata-io/build.gradle index ff29cb5fff47d2..9f5fc109eea7f6 100644 --- a/metadata-io/build.gradle +++ b/metadata-io/build.gradle @@ -28,7 +28,6 @@ dependencies { implementation externalDependency.guava implementation externalDependency.reflections - implementation 'com.github.java-json-tools:json-patch:1.13' // TODO: Replace with jakarta.json api(externalDependency.dgraph4j) { exclude group: 'com.google.guava', module: 'guava' exclude group: 'io.grpc', module: 'grpc-protobuf' diff --git a/metadata-io/metadata-io-api/src/main/java/com/linkedin/metadata/entity/ebean/batch/MCLItemImpl.java b/metadata-io/metadata-io-api/src/main/java/com/linkedin/metadata/entity/ebean/batch/MCLItemImpl.java index 94d60d2f67c9c8..a5afd4651ed2c4 100644 --- a/metadata-io/metadata-io-api/src/main/java/com/linkedin/metadata/entity/ebean/batch/MCLItemImpl.java +++ b/metadata-io/metadata-io-api/src/main/java/com/linkedin/metadata/entity/ebean/batch/MCLItemImpl.java @@ -6,6 +6,7 @@ import com.linkedin.events.metadata.ChangeType; import com.linkedin.metadata.aspect.AspectRetriever; import com.linkedin.metadata.aspect.batch.MCLItem; +import com.linkedin.metadata.aspect.batch.MCPItem; import com.linkedin.metadata.entity.AspectUtils; import com.linkedin.metadata.entity.validation.ValidationApiUtils; import com.linkedin.metadata.models.AspectSpec; @@ -13,7 +14,9 @@ import com.linkedin.metadata.models.registry.EntityRegistry; import com.linkedin.metadata.utils.EntityKeyUtils; import com.linkedin.metadata.utils.GenericRecordUtils; +import com.linkedin.metadata.utils.PegasusUtils; import com.linkedin.mxe.MetadataChangeLog; +import com.linkedin.mxe.SystemMetadata; import com.linkedin.util.Pair; import javax.annotation.Nonnull; import javax.annotation.Nullable; @@ -43,6 +46,27 @@ private MCLItemImpl build() { return null; } + public MCLItemImpl build( + MCPItem mcpItem, + @Nullable RecordTemplate oldAspectValue, + @Nullable SystemMetadata oldSystemMetadata, + AspectRetriever aspectRetriever) { + return MCLItemImpl.builder() + .build( + PegasusUtils.constructMCL( + mcpItem.getMetadataChangeProposal(), + mcpItem.getUrn().getEntityType(), + mcpItem.getUrn(), + mcpItem.getChangeType(), + mcpItem.getAspectName(), + mcpItem.getAuditStamp(), + mcpItem.getRecordTemplate(), + mcpItem.getSystemMetadata(), + oldAspectValue, + oldSystemMetadata), + aspectRetriever); + } + public MCLItemImpl build(MetadataChangeLog metadataChangeLog, AspectRetriever aspectRetriever) { return MCLItemImpl.builder().metadataChangeLog(metadataChangeLog).build(aspectRetriever); } diff --git a/metadata-io/metadata-io-api/src/main/java/com/linkedin/metadata/entity/validation/ValidationApiUtils.java b/metadata-io/metadata-io-api/src/main/java/com/linkedin/metadata/entity/validation/ValidationApiUtils.java index ed79f23823a845..f7e639ecf36038 100644 --- a/metadata-io/metadata-io-api/src/main/java/com/linkedin/metadata/entity/validation/ValidationApiUtils.java +++ b/metadata-io/metadata-io-api/src/main/java/com/linkedin/metadata/entity/validation/ValidationApiUtils.java @@ -3,6 +3,7 @@ import com.linkedin.common.urn.Urn; import com.linkedin.data.schema.validation.ValidationResult; import com.linkedin.data.template.RecordTemplate; +import com.linkedin.metadata.Constants; import com.linkedin.metadata.aspect.AspectRetriever; import com.linkedin.metadata.entity.EntityApiUtils; import com.linkedin.metadata.models.AspectSpec; @@ -51,7 +52,8 @@ public static void validateUrn(@Nonnull EntityRegistry entityRegistry, @Nonnull throw new IllegalArgumentException( "Error: cannot provide an URN with leading or trailing whitespace"); } - if (URLEncoder.encode(urn.toString()).length() > URN_NUM_BYTES_LIMIT) { + if (!Constants.SCHEMA_FIELD_ENTITY_NAME.equals(urn.getEntityType()) + && URLEncoder.encode(urn.toString()).length() > URN_NUM_BYTES_LIMIT) { throw new IllegalArgumentException( "Error: cannot provide an URN longer than " + Integer.toString(URN_NUM_BYTES_LIMIT) diff --git a/metadata-io/src/main/java/com/linkedin/metadata/entity/EntityServiceImpl.java b/metadata-io/src/main/java/com/linkedin/metadata/entity/EntityServiceImpl.java index 3e640365f3fd2a..2e12b52194ffbb 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/entity/EntityServiceImpl.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/entity/EntityServiceImpl.java @@ -777,11 +777,7 @@ public List ingestAspects( List mclResults = emitMCL(opContext, ingestResults, emitMCL); processPostCommitMCLSideEffects( - opContext, - mclResults.stream() - .filter(result -> !result.isNoOp()) - .map(UpdateAspectResult::toMCL) - .collect(Collectors.toList())); + opContext, mclResults.stream().map(UpdateAspectResult::toMCL).collect(Collectors.toList())); return mclResults; } diff --git a/metadata-io/src/main/java/com/linkedin/metadata/entity/ebean/EbeanAspectDao.java b/metadata-io/src/main/java/com/linkedin/metadata/entity/ebean/EbeanAspectDao.java index 9725abdf7fdc27..524e947476122b 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/entity/ebean/EbeanAspectDao.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/entity/ebean/EbeanAspectDao.java @@ -512,6 +512,9 @@ public PartitionedStream streamAspectBatches(final RestoreIndices if (args.aspectName != null) { exp = exp.eq(EbeanAspectV2.ASPECT_COLUMN, args.aspectName); } + if (args.aspectNames != null && !args.aspectNames.isEmpty()) { + exp = exp.in(EbeanAspectV2.ASPECT_COLUMN, args.aspectNames); + } if (args.urn != null) { exp = exp.eq(EbeanAspectV2.URN_COLUMN, args.urn); } diff --git a/metadata-io/src/main/java/com/linkedin/metadata/schemafields/sideeffects/SchemaFieldSideEffect.java b/metadata-io/src/main/java/com/linkedin/metadata/schemafields/sideeffects/SchemaFieldSideEffect.java new file mode 100644 index 00000000000000..2e86a4251a25c3 --- /dev/null +++ b/metadata-io/src/main/java/com/linkedin/metadata/schemafields/sideeffects/SchemaFieldSideEffect.java @@ -0,0 +1,627 @@ +package com.linkedin.metadata.schemafields.sideeffects; + +import static com.linkedin.metadata.Constants.APP_SOURCE; +import static com.linkedin.metadata.Constants.DATASET_ENTITY_NAME; +import static com.linkedin.metadata.Constants.SCHEMA_FIELD_ALIASES_ASPECT; +import static com.linkedin.metadata.Constants.SCHEMA_FIELD_ENTITY_NAME; +import static com.linkedin.metadata.Constants.SCHEMA_FIELD_KEY_ASPECT; +import static com.linkedin.metadata.Constants.SCHEMA_METADATA_ASPECT_NAME; +import static com.linkedin.metadata.Constants.STATUS_ASPECT_NAME; +import static com.linkedin.metadata.Constants.SYSTEM_UPDATE_SOURCE; + +import com.linkedin.common.AuditStamp; +import com.linkedin.common.Status; +import com.linkedin.common.UrnArray; +import com.linkedin.common.urn.Urn; +import com.linkedin.common.urn.UrnUtils; +import com.linkedin.entity.Aspect; +import com.linkedin.events.metadata.ChangeType; +import com.linkedin.metadata.Constants; +import com.linkedin.metadata.aspect.AspectRetriever; +import com.linkedin.metadata.aspect.RetrieverContext; +import com.linkedin.metadata.aspect.batch.BatchItem; +import com.linkedin.metadata.aspect.batch.ChangeMCP; +import com.linkedin.metadata.aspect.batch.MCLItem; +import com.linkedin.metadata.aspect.batch.MCPItem; +import com.linkedin.metadata.aspect.plugins.config.AspectPluginConfig; +import com.linkedin.metadata.aspect.plugins.hooks.MCPSideEffect; +import com.linkedin.metadata.entity.ebean.batch.ChangeItemImpl; +import com.linkedin.metadata.entity.ebean.batch.DeleteItemImpl; +import com.linkedin.metadata.key.SchemaFieldKey; +import com.linkedin.metadata.models.registry.EntityRegistry; +import com.linkedin.metadata.timeline.data.ChangeCategory; +import com.linkedin.metadata.timeline.data.ChangeEvent; +import com.linkedin.metadata.timeline.data.ChangeOperation; +import com.linkedin.metadata.timeline.eventgenerator.ChangeEventGeneratorUtils; +import com.linkedin.metadata.timeline.eventgenerator.EntityChangeEventGeneratorRegistry; +import com.linkedin.metadata.utils.SchemaFieldUtils; +import com.linkedin.mxe.SystemMetadata; +import com.linkedin.schema.SchemaMetadata; +import com.linkedin.schemafield.SchemaFieldAliases; +import com.linkedin.util.Pair; +import java.util.Collection; +import java.util.HashMap; +import java.util.List; +import java.util.Map; +import java.util.Objects; +import java.util.Optional; +import java.util.Set; +import java.util.stream.Collectors; +import java.util.stream.Stream; +import javax.annotation.Nonnull; +import javax.annotation.Nullable; +import lombok.Getter; +import lombok.Setter; +import lombok.experimental.Accessors; +import lombok.extern.slf4j.Slf4j; + +@Slf4j +@Getter +@Setter +@Accessors(chain = true) +public class SchemaFieldSideEffect extends MCPSideEffect { + @Nonnull private AspectPluginConfig config; + @Nonnull private EntityChangeEventGeneratorRegistry entityChangeEventGeneratorRegistry; + + private static final Set REQUIRED_ASPECTS = + Set.of(SCHEMA_METADATA_ASPECT_NAME, STATUS_ASPECT_NAME); + + @Override + protected Stream applyMCPSideEffect( + Collection changeMCPs, @Nonnull RetrieverContext retrieverContext) { + return Stream.of(); + } + + /** + * Handle delete of dataset schema metadata + * + * @param mclItems MCL items generated from committing the MCP + * @param retrieverContext accessors for aspect and graph data + * @return + */ + @Override + protected Stream postMCPSideEffect( + Collection mclItems, @Nonnull RetrieverContext retrieverContext) { + + // fetch existing aspects, if not already in the batch just committed + Map> aspectData = + fetchRequiredAspects(mclItems, REQUIRED_ASPECTS, retrieverContext.getAspectRetriever()); + + return Stream.concat( + processUpserts(mclItems, aspectData, retrieverContext), + processDelete(mclItems, aspectData, retrieverContext)); + } + + private static Stream processDelete( + Collection mclItems, + Map> aspectData, + @Nonnull RetrieverContext retrieverContext) { + + List schemaMetadataDeletes = + mclItems.stream() + .filter( + item -> + ChangeType.DELETE.equals(item.getChangeType()) + && DATASET_ENTITY_NAME.equals(item.getUrn().getEntityType()) + && SCHEMA_METADATA_ASPECT_NAME.equals(item.getAspectName())) + .collect(Collectors.toList()); + + Stream schemaMetadataSchemaFieldMCPs = + schemaMetadataDeletes.stream() + .flatMap( + item -> + buildSchemaMetadataSchemaFieldDeleteMCPs( + item, retrieverContext.getAspectRetriever())); + + List statusDeletes = + mclItems.stream() + .filter( + item -> + ChangeType.DELETE.equals(item.getChangeType()) + && DATASET_ENTITY_NAME.equals(item.getUrn().getEntityType()) + && STATUS_ASPECT_NAME.equals(item.getAspectName())) + .collect(Collectors.toList()); + + final Stream statusSchemaFieldMCPs; + if (statusDeletes.isEmpty()) { + statusSchemaFieldMCPs = Stream.empty(); + } else { + statusSchemaFieldMCPs = + statusDeletes.stream() + .flatMap( + item -> + buildStatusSchemaFieldDeleteMCPs( + item, + Optional.ofNullable( + aspectData + .getOrDefault(item.getUrn(), Map.of()) + .get(SCHEMA_METADATA_ASPECT_NAME)) + .map(aspect -> new SchemaMetadata(aspect.data())) + .orElse(null), + retrieverContext.getAspectRetriever())); + } + + return Stream.concat(schemaMetadataSchemaFieldMCPs, statusSchemaFieldMCPs); + } + + private Stream processUpserts( + Collection mclItems, + Map> aspectData, + @Nonnull RetrieverContext retrieverContext) { + + Map> batchMCPAspectNames = + mclItems.stream() + .filter(item -> item.getChangeType() != ChangeType.DELETE) + .collect( + Collectors.groupingBy( + MCLItem::getUrn, + Collectors.mapping(MCLItem::getAspectName, Collectors.toSet()))); + + Stream schemaFieldSideEffects = + mclItems.stream() + .filter( + changeMCP -> + changeMCP.getChangeType() != ChangeType.DELETE + && DATASET_ENTITY_NAME.equals(changeMCP.getUrn().getEntityType()) + && Constants.SCHEMA_METADATA_ASPECT_NAME.equals(changeMCP.getAspectName())) + .flatMap( + // Build schemaField Keys and Aliases + item -> + optimizedKeyAspectMCPsConcat( + buildSchemaFieldKeyMCPs( + item, aspectData, retrieverContext.getAspectRetriever()), + buildSchemaFieldAliasesMCPs(item, retrieverContext.getAspectRetriever()))); + + Stream statusSideEffects = + mclItems.stream() + .filter( + changeMCP -> + changeMCP.getChangeType() != ChangeType.DELETE + && DATASET_ENTITY_NAME.equals(changeMCP.getUrn().getEntityType()) + && Constants.STATUS_ASPECT_NAME.equals(changeMCP.getAspectName()) + // if present, already computed above + && !batchMCPAspectNames + .getOrDefault(changeMCP.getUrn(), Set.of()) + .contains(Constants.SCHEMA_METADATA_ASPECT_NAME)) + .flatMap( + item -> + mirrorStatusAspect(item, aspectData, retrieverContext.getAspectRetriever())); + + Stream removedFieldStatusSideEffects = + mclItems.stream() + .filter( + changeMCP -> + changeMCP.getChangeType() != ChangeType.DELETE + && DATASET_ENTITY_NAME.equals(changeMCP.getUrn().getEntityType()) + && SCHEMA_METADATA_ASPECT_NAME.equals(changeMCP.getAspectName()) + && changeMCP.getPreviousRecordTemplate() != null) + .flatMap( + item -> + buildRemovedSchemaFieldStatusAspect( + item, retrieverContext.getAspectRetriever())); + + return optimizedKeyAspectMCPsConcat( + Stream.concat(schemaFieldSideEffects, statusSideEffects), removedFieldStatusSideEffects); + } + + /** + * Copy aspect from dataset to schema fields + * + * @param parentDatasetStatusItem dataset mcp item + * @param aspectRetriever aspectRetriever context + * @return side effect schema field aspects + */ + private static Stream mirrorStatusAspect( + BatchItem parentDatasetStatusItem, + Map> aspectData, + @Nonnull AspectRetriever aspectRetriever) { + + SchemaMetadata schemaMetadata = + Optional.ofNullable( + aspectData + .getOrDefault(parentDatasetStatusItem.getUrn(), Map.of()) + .getOrDefault(Constants.SCHEMA_METADATA_ASPECT_NAME, null)) + .map(aspect -> new SchemaMetadata(aspect.data())) + .orElse(null); + + if (schemaMetadata != null) { + return schemaMetadata.getFields().stream() + .map( + schemaField -> { + Boolean removed = + parentDatasetStatusItem.getRecordTemplate() != null + ? parentDatasetStatusItem.getAspect(Status.class).isRemoved() + : null; + return buildSchemaFieldStatusMCPs( + SchemaFieldUtils.generateSchemaFieldUrn( + parentDatasetStatusItem.getUrn(), schemaField), + removed, + parentDatasetStatusItem.getAuditStamp(), + parentDatasetStatusItem.getSystemMetadata(), + aspectRetriever); + }); + } + + return Stream.empty(); + } + + /** + * Build a schema field status MCP based on the input status from the dataset + * + * @param schemaFieldUrn schema fields's urn + * @param removed removed status + * @param datasetAuditStamp origin audit stamp + * @param datasetSystemMetadata origin system metadata + * @param aspectRetriever aspect retriever + * @return stream of status aspects for schema fields + */ + public static ChangeMCP buildSchemaFieldStatusMCPs( + Urn schemaFieldUrn, + @Nullable Boolean removed, + AuditStamp datasetAuditStamp, + SystemMetadata datasetSystemMetadata, + @Nonnull AspectRetriever aspectRetriever) { + return ChangeItemImpl.builder() + .urn(schemaFieldUrn) + .changeType(ChangeType.UPSERT) + .aspectName(STATUS_ASPECT_NAME) + .recordTemplate(new Status().setRemoved(removed != null ? removed : false)) + .auditStamp(datasetAuditStamp) + .systemMetadata(datasetSystemMetadata) + .build(aspectRetriever); + } + + private Stream buildRemovedSchemaFieldStatusAspect( + MCLItem parentDatasetSchemaMetadataItem, @Nonnull AspectRetriever aspectRetriever) { + + List changeEvents = + ChangeEventGeneratorUtils.generateChangeEvents( + entityChangeEventGeneratorRegistry, + parentDatasetSchemaMetadataItem.getUrn(), + parentDatasetSchemaMetadataItem.getEntitySpec().getName(), + parentDatasetSchemaMetadataItem.getAspectName(), + new com.linkedin.metadata.timeline.eventgenerator.Aspect<>( + parentDatasetSchemaMetadataItem.getPreviousAspect(SchemaMetadata.class), + parentDatasetSchemaMetadataItem.getPreviousSystemMetadata()), + new com.linkedin.metadata.timeline.eventgenerator.Aspect<>( + parentDatasetSchemaMetadataItem.getAspect(SchemaMetadata.class), + parentDatasetSchemaMetadataItem.getSystemMetadata()), + parentDatasetSchemaMetadataItem.getAuditStamp()); + + return changeEvents.stream() + .flatMap( + changeEvent -> + createRemovedStatusItem( + changeEvent, parentDatasetSchemaMetadataItem, aspectRetriever) + .stream()); + } + + private static Optional createRemovedStatusItem( + @Nonnull final ChangeEvent changeEvent, + @Nonnull final MCLItem parentDatasetSchemaMetadataItem, + @Nonnull AspectRetriever aspectRetriever) { + + if (changeEvent.getCategory().equals(ChangeCategory.TECHNICAL_SCHEMA)) { + if (log.isDebugEnabled()) { + // Protect against expensive toString() call + String parameterString = ""; + if (changeEvent.getParameters() != null) { + parameterString = + changeEvent.getParameters().entrySet().stream() + .map(entry -> entry.getKey() + ":" + entry.getValue()) + .collect(Collectors.joining(",")); + } + log.debug( + "Technical Schema Event: Entity: {}\nOperation: {}\nModifier: {}\nAuditStamp: {}\nParameters:{}\nCategory:{} ", + changeEvent.getEntityUrn(), + changeEvent.getOperation(), + changeEvent.getModifier(), + changeEvent.getAuditStamp(), + parameterString, + changeEvent.getCategory()); + } + if (changeEvent.getOperation().equals(ChangeOperation.REMOVE)) { + String fieldPath = changeEvent.getModifier().toString(); + log.debug("Creating status change proposal {} for field: {}", true, fieldPath); + return Optional.of( + buildSchemaFieldStatusMCPs( + UrnUtils.getUrn(fieldPath), + true, + parentDatasetSchemaMetadataItem.getAuditStamp(), + parentDatasetSchemaMetadataItem.getSystemMetadata(), + aspectRetriever)); + } + } + return Optional.empty(); + } + + /** + * Expand dataset schemaMetadata to schemaFields + * + * @param parentDatasetMetadataSchemaItem dataset mcp item + * @param aspectRetriever aspectRetriever context + * @return side effect schema field aspects + */ + private static Stream buildSchemaFieldKeyMCPs( + MCLItem parentDatasetMetadataSchemaItem, + Map> aspectData, + @Nonnull AspectRetriever aspectRetriever) { + + Stream schemaFieldKeys = + buildSchemaFieldKeyMCPs(parentDatasetMetadataSchemaItem, aspectRetriever); + + // Handle case where dataset status created before schema metadata + final Stream statusSideEffects; + if (aspectData + .getOrDefault(parentDatasetMetadataSchemaItem.getUrn(), Map.of()) + .containsKey(STATUS_ASPECT_NAME)) { + Status status = + new Status( + aspectData + .get(parentDatasetMetadataSchemaItem.getUrn()) + .get(STATUS_ASPECT_NAME) + .data()); + + ChangeItemImpl datasetStatusItem = + ChangeItemImpl.builder() + .changeType(ChangeType.UPSERT) + .urn(parentDatasetMetadataSchemaItem.getUrn()) + .aspectName(STATUS_ASPECT_NAME) + .entitySpec(parentDatasetMetadataSchemaItem.getEntitySpec()) + .aspectSpec( + parentDatasetMetadataSchemaItem.getEntitySpec().getAspectSpec(STATUS_ASPECT_NAME)) + .recordTemplate(status) + .auditStamp(parentDatasetMetadataSchemaItem.getAuditStamp()) + .systemMetadata(parentDatasetMetadataSchemaItem.getSystemMetadata()) + .build(aspectRetriever); + statusSideEffects = mirrorStatusAspect(datasetStatusItem, aspectData, aspectRetriever); + } else { + statusSideEffects = Stream.empty(); + } + + return optimizedKeyAspectMCPsConcat(schemaFieldKeys, statusSideEffects); + } + + /** + * Given a dataset's metadata schema item, generate schema field key aspects + * + * @param parentDatasetMetadataSchemaItem dataset's metadata schema MCP + * @param aspectRetriever retriever + * @return stream of schema field MCPs for its key aspect + */ + private static Stream buildSchemaFieldKeyMCPs( + @Nonnull MCLItem parentDatasetMetadataSchemaItem, @Nonnull AspectRetriever aspectRetriever) { + + SystemMetadata systemMetadata = parentDatasetMetadataSchemaItem.getSystemMetadata(); + SchemaMetadata schemaMetadata = parentDatasetMetadataSchemaItem.getAspect(SchemaMetadata.class); + SchemaMetadata previousSchemaMetadata = + parentDatasetMetadataSchemaItem.getPreviousRecordTemplate() != null + ? parentDatasetMetadataSchemaItem.getPreviousAspect(SchemaMetadata.class) + : null; + + return schemaMetadata.getFields().stream() + .filter( + schemaField -> + ChangeType.RESTATE.equals(parentDatasetMetadataSchemaItem.getChangeType()) + || previousSchemaMetadata == null + // avoid processing already existing fields + || !previousSchemaMetadata.getFields().contains(schemaField) + // system update pass through + || isSystemUpdate(systemMetadata)) + .map( + schemaField -> + ChangeItemImpl.builder() + .urn( + SchemaFieldUtils.generateSchemaFieldUrn( + parentDatasetMetadataSchemaItem.getUrn(), schemaField)) + .changeType(ChangeType.UPSERT) + .aspectName(SCHEMA_FIELD_KEY_ASPECT) + .recordTemplate( + new SchemaFieldKey() + .setFieldPath(schemaField.getFieldPath()) + .setParent(parentDatasetMetadataSchemaItem.getUrn())) + .auditStamp(parentDatasetMetadataSchemaItem.getAuditStamp()) + .systemMetadata(parentDatasetMetadataSchemaItem.getSystemMetadata()) + .build(aspectRetriever)); + } + + /** + * Given a dataset's metadata schema item, generate schema field alias aspects + * + * @param parentDatasetMetadataSchemaItem dataset's metadata schema MCP + * @param aspectRetriever retriever + * @return stream of schema field aliases for its key aspect + */ + private static Stream buildSchemaFieldAliasesMCPs( + @Nonnull MCLItem parentDatasetMetadataSchemaItem, @Nonnull AspectRetriever aspectRetriever) { + + SystemMetadata systemMetadata = parentDatasetMetadataSchemaItem.getSystemMetadata(); + SchemaMetadata schemaMetadata = parentDatasetMetadataSchemaItem.getAspect(SchemaMetadata.class); + SchemaMetadata previousSchemaMetadata = + parentDatasetMetadataSchemaItem.getPreviousRecordTemplate() != null + ? parentDatasetMetadataSchemaItem.getPreviousAspect(SchemaMetadata.class) + : null; + + return schemaMetadata.getFields().stream() + .filter( + schemaField -> + ChangeType.RESTATE.equals(parentDatasetMetadataSchemaItem.getChangeType()) + || previousSchemaMetadata == null + || !previousSchemaMetadata.getFields().equals(schemaMetadata.getFields()) + // system update pass through + || isSystemUpdate(systemMetadata)) + .map( + schemaField -> { + Set currentAliases = + SchemaFieldUtils.getSchemaFieldAliases( + parentDatasetMetadataSchemaItem.getUrn(), schemaMetadata, schemaField); + Set previousAliases = + previousSchemaMetadata == null + ? Set.of() + : SchemaFieldUtils.getSchemaFieldAliases( + parentDatasetMetadataSchemaItem.getUrn(), + previousSchemaMetadata, + schemaField); + + boolean forceUpdate = + isSystemUpdate(systemMetadata) + || ChangeType.RESTATE.equals(parentDatasetMetadataSchemaItem.getChangeType()); + if (!previousAliases.equals(currentAliases) || forceUpdate) { + return ChangeItemImpl.builder() + .urn( + SchemaFieldUtils.generateSchemaFieldUrn( + parentDatasetMetadataSchemaItem.getUrn(), schemaField)) + .changeType(ChangeType.UPSERT) + .aspectName(SCHEMA_FIELD_ALIASES_ASPECT) + .recordTemplate( + new SchemaFieldAliases().setAliases(new UrnArray(currentAliases))) + .auditStamp(parentDatasetMetadataSchemaItem.getAuditStamp()) + .systemMetadata(parentDatasetMetadataSchemaItem.getSystemMetadata()) + .build(aspectRetriever); + } + + return (ChangeMCP) null; + }) + .filter(Objects::nonNull); + } + + /** + * Given a delete MCL for a dataset's schema metadata, generate delete MCPs for the schemaField + * aspects + * + * @param parentDatasetSchemaMetadataDelete the dataset's MCL from a metadata schema delete + * @param aspectRetriever retriever context + * @return follow-up deletes for the schema field + */ + public static Stream buildSchemaMetadataSchemaFieldDeleteMCPs( + @Nonnull MCLItem parentDatasetSchemaMetadataDelete, + @Nonnull AspectRetriever aspectRetriever) { + + EntityRegistry entityRegistry = aspectRetriever.getEntityRegistry(); + Urn datasetUrn = parentDatasetSchemaMetadataDelete.getUrn(); + SchemaMetadata parentDatasetSchemaMetadata = + parentDatasetSchemaMetadataDelete.getPreviousAspect(SchemaMetadata.class); + + return parentDatasetSchemaMetadata.getFields().stream() + .flatMap( + schemaField -> + entityRegistry.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME).getAspectSpecs().stream() + .map( + aspectSpec -> + DeleteItemImpl.builder() + .urn( + SchemaFieldUtils.generateSchemaFieldUrn( + datasetUrn, schemaField)) + .aspectName(aspectSpec.getName()) + .auditStamp(parentDatasetSchemaMetadataDelete.getAuditStamp()) + .entitySpec(entityRegistry.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)) + .aspectSpec(aspectSpec) + .build(aspectRetriever))); + } + + public static Stream buildStatusSchemaFieldDeleteMCPs( + @Nonnull MCLItem parentDatasetStatusDelete, + @Nullable SchemaMetadata parentDatasetSchemaMetadata, + @Nonnull AspectRetriever aspectRetriever) { + + if (parentDatasetSchemaMetadata == null) { + return Stream.empty(); + } else { + EntityRegistry entityRegistry = aspectRetriever.getEntityRegistry(); + return parentDatasetSchemaMetadata.getFields().stream() + .map( + schemaField -> + DeleteItemImpl.builder() + .urn( + SchemaFieldUtils.generateSchemaFieldUrn( + parentDatasetStatusDelete.getUrn(), schemaField)) + .aspectName(STATUS_ASPECT_NAME) + .auditStamp(parentDatasetStatusDelete.getAuditStamp()) + .entitySpec(entityRegistry.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)) + .aspectSpec(parentDatasetStatusDelete.getAspectSpec()) + .build(aspectRetriever)); + } + } + + /** + * Fetch missing aspects if not already in the batch + * + * @param mclItems batch mcps + * @param aspectRetriever aspect retriever + * @return required aspects for the side effect processing + */ + private static Map> fetchRequiredAspects( + Collection mclItems, + Set requiredAspectNames, + AspectRetriever aspectRetriever) { + Map> aspectData = new HashMap<>(); + + // Aspects included data in batch + mclItems.stream() + .filter(item -> item.getRecordTemplate() != null) + .forEach( + item -> + aspectData + .computeIfAbsent(item.getUrn(), k -> new HashMap<>()) + .put(item.getAspectName(), new Aspect(item.getRecordTemplate().data()))); + + // Aspect to fetch + Map> missingAspectData = + mclItems.stream() + .flatMap( + item -> + requiredAspectNames.stream() + .filter( + aspectName -> + !aspectData + .getOrDefault(item.getUrn(), Map.of()) + .containsKey(aspectName)) + .map(aspectName -> Pair.of(item.getUrn(), aspectName))) + .collect( + Collectors.groupingBy( + Pair::getKey, Collectors.mapping(Pair::getValue, Collectors.toSet()))); + + // Fetch missing + missingAspectData.forEach( + (urn, aspectNames) -> { + Map fetchedData = + aspectRetriever.getLatestAspectObjects(Set.of(urn), aspectNames).get(urn); + if (fetchedData != null) { + fetchedData.forEach( + (aspectName, aspectValue) -> + aspectData + .computeIfAbsent(urn, k -> new HashMap<>()) + .put(aspectName, aspectValue)); + } + }); + + return aspectData; + } + + /** + * We can reduce the number of MCPs sent via kafka by 1/2 to 1/3 because key aspects are + * automatically created if they don't exist. The only case where there needs to be an explicit + * key aspect is when there are no other aspects being generated. + * + * @param keyMCPs stream of MCPs which *may* contain key aspects + * @param otherMCPs stream of MCPs which are not expected to contain key aspects + * @return reduced stream of MCPs + */ + private static Stream optimizedKeyAspectMCPsConcat( + Stream keyMCPs, Stream otherMCPs) { + List other = otherMCPs.collect(Collectors.toList()); + Set otherUrns = other.stream().map(T::getUrn).collect(Collectors.toSet()); + return Stream.concat( + keyMCPs.filter( + item -> + !item.getAspectName().equals(item.getEntitySpec().getKeyAspectName()) + || !otherUrns.contains(item.getUrn())), + other.stream()); + } + + private static boolean isSystemUpdate(@Nullable SystemMetadata systemMetadata) { + return systemMetadata != null + && systemMetadata.getProperties() != null + && SYSTEM_UPDATE_SOURCE.equals(systemMetadata.getProperties().get(APP_SOURCE)); + } +} diff --git a/metadata-io/src/main/java/com/linkedin/metadata/search/LineageSearchService.java b/metadata-io/src/main/java/com/linkedin/metadata/search/LineageSearchService.java index d07882963e2811..84fcc2c0a0f911 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/search/LineageSearchService.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/search/LineageSearchService.java @@ -2,6 +2,7 @@ import static com.datahub.authorization.AuthUtil.canViewEntity; import static com.linkedin.metadata.Constants.*; +import static com.linkedin.metadata.search.utils.QueryUtils.buildFilterWithUrns; import static com.linkedin.metadata.search.utils.SearchUtils.applyDefaultSearchFlags; import com.google.common.annotations.VisibleForTesting; @@ -12,9 +13,8 @@ import com.linkedin.common.urn.Urn; import com.linkedin.common.urn.UrnUtils; import com.linkedin.data.template.LongMap; -import com.linkedin.data.template.StringArray; import com.linkedin.metadata.Constants; -import com.linkedin.metadata.config.cache.SearchLineageCacheConfiguration; +import com.linkedin.metadata.config.DataHubAppConfiguration; import com.linkedin.metadata.graph.EntityLineageResult; import com.linkedin.metadata.graph.GraphService; import com.linkedin.metadata.graph.LineageDirection; @@ -32,7 +32,6 @@ import com.linkedin.metadata.query.filter.SortCriterion; import com.linkedin.metadata.search.cache.CachedEntityLineageResult; import com.linkedin.metadata.search.utils.FilterUtils; -import com.linkedin.metadata.search.utils.QueryUtils; import com.linkedin.metadata.search.utils.SearchUtils; import io.datahubproject.metadata.context.OperationContext; import io.opentelemetry.extension.annotations.WithSpan; @@ -81,7 +80,7 @@ public class LineageSearchService { private final GraphService _graphService; @Nullable private final Cache cache; private final boolean cacheEnabled; - private final SearchLineageCacheConfiguration cacheConfiguration; + private final DataHubAppConfiguration appConfig; private final ExecutorService cacheRefillExecutor = Executors.newFixedThreadPool(1); private static final String DEGREE_FILTER = "degree"; @@ -198,7 +197,7 @@ public LineageSearchResult searchAcrossLineage( freshnessStats.setSystemFreshness(systemFreshness); // set up cache refill if needed if (System.currentTimeMillis() - cachedLineageResult.getTimestamp() - > cacheConfiguration.getTTLMillis()) { + > appConfig.getCache().getSearch().getLineage().getTTLMillis()) { log.info("Cached lineage entry for: {} is older than one day. Will refill.", sourceUrn); Integer finalMaxHops = maxHops; this.cacheRefillExecutor.submit( @@ -208,7 +207,7 @@ public LineageSearchResult searchAcrossLineage( cache.get(cacheKey, CachedEntityLineageResult.class); if (reFetchLineageResult == null || System.currentTimeMillis() - reFetchLineageResult.getTimestamp() - > cacheConfiguration.getTTLMillis()) { + > appConfig.getCache().getSearch().getLineage().getTTLMillis()) { // we have to refetch EntityLineageResult result = _graphService.getLineage( @@ -315,7 +314,8 @@ boolean canDoLightning( criterion1 -> "platform".equals(criterion1.getField()) || "origin".equals(criterion1.getField()))); - return (lineageRelationships.size() > cacheConfiguration.getLightningThreshold()) + return (lineageRelationships.size() + > appConfig.getCache().getSearch().getLineage().getLightningThreshold()) && input.equals("*") && simpleFilters && CollectionUtils.isEmpty(sortCriteria); @@ -555,7 +555,7 @@ private LineageSearchResult getSearchResultInBatches( .distinct() .collect(Collectors.toList()); Map urnToRelationship = generateUrnToRelationshipMap(batch); - Filter finalFilter = buildFilter(urnToRelationship.keySet(), inputFilters); + Filter finalFilter = buildFilterWithUrns(appConfig, urnToRelationship.keySet(), inputFilters); LineageSearchResult resultForBatch = buildLineageSearchResult( @@ -671,27 +671,6 @@ private List filterRelationships( return relationshipsFilteredByEntities.collect(Collectors.toList()); } - private Filter buildFilter(@Nonnull Set urns, @Nullable Filter inputFilters) { - Criterion urnMatchCriterion = - new Criterion() - .setField("urn") - .setValue("") - .setValues( - new StringArray(urns.stream().map(Object::toString).collect(Collectors.toList()))); - if (inputFilters == null) { - return QueryUtils.newFilter(urnMatchCriterion); - } - - // Add urn match criterion to each or clause - if (!CollectionUtils.isEmpty(inputFilters.getOr())) { - for (ConjunctiveCriterion conjunctiveCriterion : inputFilters.getOr()) { - conjunctiveCriterion.getAnd().add(urnMatchCriterion); - } - return inputFilters; - } - return QueryUtils.newFilter(urnMatchCriterion); - } - private LineageSearchResult buildLineageSearchResult( @Nonnull OperationContext opContext, @Nonnull SearchResult searchResult, @@ -809,7 +788,7 @@ public LineageScrollResult scrollAcrossLineage( } else { lineageResult = cachedLineageResult.getEntityLineageResult(); if (System.currentTimeMillis() - cachedLineageResult.getTimestamp() - > cacheConfiguration.getTTLMillis()) { + > appConfig.getCache().getSearch().getLineage().getTTLMillis()) { log.warn("Cached lineage entry for: {} is older than one day.", sourceUrn); } } @@ -868,7 +847,7 @@ private LineageScrollResult getScrollResultInBatches( .distinct() .collect(Collectors.toList()); Map urnToRelationship = generateUrnToRelationshipMap(batch); - Filter finalFilter = buildFilter(urnToRelationship.keySet(), inputFilters); + Filter finalFilter = buildFilterWithUrns(appConfig, urnToRelationship.keySet(), inputFilters); LineageScrollResult resultForBatch = buildLineageScrollResult( diff --git a/metadata-io/src/main/java/com/linkedin/metadata/search/elasticsearch/ElasticSearchService.java b/metadata-io/src/main/java/com/linkedin/metadata/search/elasticsearch/ElasticSearchService.java index 4d5fe8d0b8e607..9905d5e7790ade 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/search/elasticsearch/ElasticSearchService.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/search/elasticsearch/ElasticSearchService.java @@ -18,8 +18,8 @@ import com.linkedin.metadata.search.elasticsearch.query.ESSearchDAO; import com.linkedin.metadata.search.elasticsearch.update.ESWriteDAO; import com.linkedin.metadata.search.utils.ESUtils; -import com.linkedin.metadata.search.utils.SearchUtils; import com.linkedin.metadata.shared.ElasticSearchIndexed; +import com.linkedin.metadata.utils.elasticsearch.IndexConvention; import com.linkedin.structured.StructuredPropertyDefinition; import com.linkedin.util.Pair; import io.datahubproject.metadata.context.OperationContext; @@ -108,13 +108,8 @@ public void appendRunId( @Nonnull String entityName, @Nonnull Urn urn, @Nullable String runId) { - final Optional maybeDocId = SearchUtils.getDocId(urn); - if (!maybeDocId.isPresent()) { - log.warn( - String.format("Failed to append run id, could not generate a doc id for urn %s", urn)); - return; - } - final String docId = maybeDocId.get(); + final String docId = indexBuilders.getIndexConvention().getEntityDocumentId(urn); + log.info( "Appending run id for entity name: {}, doc id: {}, run id: {}", entityName, docId, runId); esWriteDAO.applyScriptUpdate( @@ -419,4 +414,9 @@ public ExplainResponse explain( size, facets); } + + @Override + public IndexConvention getIndexConvention() { + return indexBuilders.getIndexConvention(); + } } diff --git a/metadata-io/src/main/java/com/linkedin/metadata/search/elasticsearch/indexbuilder/EntityIndexBuilders.java b/metadata-io/src/main/java/com/linkedin/metadata/search/elasticsearch/indexbuilder/EntityIndexBuilders.java index eba4593c9042c5..6f1d7f74f15427 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/search/elasticsearch/indexbuilder/EntityIndexBuilders.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/search/elasticsearch/indexbuilder/EntityIndexBuilders.java @@ -12,6 +12,7 @@ import java.util.Map; import java.util.Objects; import java.util.stream.Collectors; +import lombok.Getter; import lombok.RequiredArgsConstructor; import lombok.extern.slf4j.Slf4j; @@ -20,7 +21,7 @@ public class EntityIndexBuilders implements ElasticSearchIndexed { private final ESIndexBuilder indexBuilder; private final EntityRegistry entityRegistry; - private final IndexConvention indexConvention; + @Getter private final IndexConvention indexConvention; private final SettingsBuilder settingsBuilder; public ESIndexBuilder getIndexBuilder() { diff --git a/metadata-io/src/main/java/com/linkedin/metadata/search/utils/SearchUtils.java b/metadata-io/src/main/java/com/linkedin/metadata/search/utils/SearchUtils.java index 3ddc004dd9fa9f..add2b1526ab675 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/search/utils/SearchUtils.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/search/utils/SearchUtils.java @@ -3,7 +3,6 @@ import static com.linkedin.metadata.Constants.*; import com.linkedin.common.UrnArray; -import com.linkedin.common.urn.Urn; import com.linkedin.data.template.LongMap; import com.linkedin.metadata.query.ListResult; import com.linkedin.metadata.query.SearchFlags; @@ -19,11 +18,8 @@ import com.linkedin.metadata.utils.SearchUtil; import java.io.IOException; import java.io.InputStream; -import java.io.UnsupportedEncodingException; -import java.net.URLEncoder; import java.util.Collections; import java.util.Map; -import java.util.Optional; import java.util.Set; import java.util.function.Predicate; import java.util.stream.Collectors; @@ -39,15 +35,6 @@ public class SearchUtils { private SearchUtils() {} - public static Optional getDocId(@Nonnull Urn urn) { - try { - return Optional.of(URLEncoder.encode(urn.toString(), "UTF-8")); - } catch (UnsupportedEncodingException e) { - log.error("Failed to encode the urn with error: {}", e.toString()); - return Optional.empty(); - } - } - /** * Validates the request params and create a request map out of it. * diff --git a/metadata-io/src/main/java/com/linkedin/metadata/service/UpdateIndicesService.java b/metadata-io/src/main/java/com/linkedin/metadata/service/UpdateIndicesService.java index 2ab9e17f281637..2274b0a7c1cd82 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/service/UpdateIndicesService.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/service/UpdateIndicesService.java @@ -14,7 +14,6 @@ import com.linkedin.common.Status; import com.linkedin.common.UrnArray; import com.linkedin.common.urn.Urn; -import com.linkedin.common.urn.UrnUtils; import com.linkedin.data.template.RecordTemplate; import com.linkedin.datajob.DataJobInputOutput; import com.linkedin.dataset.FineGrainedLineage; @@ -30,7 +29,6 @@ import com.linkedin.metadata.graph.GraphIndexUtils; import com.linkedin.metadata.graph.GraphService; import com.linkedin.metadata.graph.dgraph.DgraphGraphService; -import com.linkedin.metadata.key.SchemaFieldKey; import com.linkedin.metadata.models.AspectSpec; import com.linkedin.metadata.models.EntitySpec; import com.linkedin.metadata.models.RelationshipFieldSpec; @@ -41,11 +39,10 @@ import com.linkedin.metadata.search.EntitySearchService; import com.linkedin.metadata.search.elasticsearch.indexbuilder.EntityIndexBuilders; import com.linkedin.metadata.search.transformer.SearchDocumentTransformer; -import com.linkedin.metadata.search.utils.SearchUtils; import com.linkedin.metadata.systemmetadata.SystemMetadataService; import com.linkedin.metadata.timeseries.TimeseriesAspectService; import com.linkedin.metadata.timeseries.transformer.TimeseriesAspectTransformer; -import com.linkedin.metadata.utils.EntityKeyUtils; +import com.linkedin.metadata.utils.SchemaFieldUtils; import com.linkedin.mxe.MetadataChangeLog; import com.linkedin.mxe.SystemMetadata; import com.linkedin.structured.StructuredPropertyDefinition; @@ -327,17 +324,6 @@ private void updateFineGrainedEdgesAndRelationships( } } - private Urn generateSchemaFieldUrn( - @Nonnull final String resourceUrn, @Nonnull final String fieldPath) { - // we rely on schemaField fieldPaths to be encoded since we do that with fineGrainedLineage on - // the ingestion side - final String encodedFieldPath = - fieldPath.replaceAll("\\(", "%28").replaceAll("\\)", "%29").replaceAll(",", "%2C"); - final SchemaFieldKey key = - new SchemaFieldKey().setParent(UrnUtils.getUrn(resourceUrn)).setFieldPath(encodedFieldPath); - return EntityKeyUtils.convertEntityKeyToUrn(key, Constants.SCHEMA_FIELD_ENTITY_NAME); - } - // TODO: remove this method once we implement sourceOverride and update inputFields aspect private void updateInputFieldEdgesAndRelationships( @Nonnull final Urn urn, @@ -350,7 +336,7 @@ private void updateInputFieldEdgesAndRelationships( && field.hasSchemaField() && field.getSchemaField().hasFieldPath()) { final Urn sourceFieldUrn = - generateSchemaFieldUrn(urn.toString(), field.getSchemaField().getFieldPath()); + SchemaFieldUtils.generateSchemaFieldUrn(urn, field.getSchemaField().getFieldPath()); // TODO: add edges uniformly across aspects edgesToAdd.add( new Edge( @@ -554,11 +540,7 @@ private void updateSearchService(@Nonnull OperationContext opContext, MCLItem ev return; } - Optional docId = SearchUtils.getDocId(urn); - - if (!docId.isPresent()) { - return; - } + final String docId = _entityIndexBuilders.getIndexConvention().getEntityDocumentId(urn); if (_searchDiffMode && (systemMetadata == null @@ -590,7 +572,7 @@ private void updateSearchService(@Nonnull OperationContext opContext, MCLItem ev searchDocument.get(), previousSearchDocument.orElse(null)) .toString(); - _entitySearchService.upsertDocument(opContext, entityName, finalDocument, docId.get()); + _entitySearchService.upsertDocument(opContext, entityName, finalDocument, docId); } /** Process snapshot and update time-series index */ diff --git a/metadata-io/src/main/java/com/linkedin/metadata/timeline/TimelineServiceImpl.java b/metadata-io/src/main/java/com/linkedin/metadata/timeline/TimelineServiceImpl.java index a93d4880a7979e..3895bf4fe2ef86 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/timeline/TimelineServiceImpl.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/timeline/TimelineServiceImpl.java @@ -3,12 +3,8 @@ import static com.linkedin.common.urn.VersionedUrnUtils.*; import static com.linkedin.metadata.Constants.*; -import com.fasterxml.jackson.core.JsonProcessingException; import com.fasterxml.jackson.core.StreamReadConstraints; -import com.fasterxml.jackson.databind.JsonNode; import com.fasterxml.jackson.databind.ObjectMapper; -import com.github.fge.jsonpatch.JsonPatch; -import com.github.fge.jsonpatch.diff.JsonDiff; import com.linkedin.common.urn.Urn; import com.linkedin.metadata.entity.AspectDao; import com.linkedin.metadata.entity.EntityAspect; @@ -30,6 +26,10 @@ import com.linkedin.metadata.timeline.eventgenerator.InstitutionalMemoryChangeEventGenerator; import com.linkedin.metadata.timeline.eventgenerator.OwnershipChangeEventGenerator; import com.linkedin.metadata.timeline.eventgenerator.SchemaMetadataChangeEventGenerator; +import jakarta.json.Json; +import jakarta.json.JsonPatch; +import jakarta.json.JsonValue; +import java.io.StringReader; import java.sql.Timestamp; import java.util.ArrayList; import java.util.Collection; @@ -478,16 +478,13 @@ private List computeDiff( } private JsonPatch getRawDiff(EntityAspect previousValue, EntityAspect currentValue) { - JsonNode prevNode = OBJECT_MAPPER.nullNode(); - try { - if (previousValue.getVersion() != -1) { - prevNode = OBJECT_MAPPER.readTree(previousValue.getMetadata()); - } - JsonNode currNode = OBJECT_MAPPER.readTree(currentValue.getMetadata()); - return JsonDiff.asJsonPatch(prevNode, currNode); - } catch (JsonProcessingException e) { - throw new IllegalStateException(e); + JsonValue prevNode = Json.createReader(new StringReader("{}")).readValue(); + if (previousValue.getVersion() != -1) { + prevNode = Json.createReader(new StringReader(previousValue.getMetadata())).readValue(); } + JsonValue currNode = + Json.createReader(new StringReader(currentValue.getMetadata())).readValue(); + return Json.createDiff(prevNode.asJsonObject(), currNode.asJsonObject()); } private void combineComputedDiffsPerTransactionId( diff --git a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/ChangeEventGeneratorUtils.java b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/ChangeEventGeneratorUtils.java index f6192294e57010..7c74788f62342a 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/ChangeEventGeneratorUtils.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/ChangeEventGeneratorUtils.java @@ -1,13 +1,16 @@ package com.linkedin.metadata.timeline.eventgenerator; +import com.linkedin.common.AuditStamp; import com.linkedin.common.urn.Urn; import com.linkedin.common.urn.UrnUtils; +import com.linkedin.data.template.RecordTemplate; import com.linkedin.metadata.timeline.data.ChangeEvent; import com.linkedin.metadata.timeline.data.dataset.schema.SchemaFieldGlossaryTermChangeEvent; import com.linkedin.metadata.timeline.data.dataset.schema.SchemaFieldTagChangeEvent; import com.linkedin.metadata.timeline.data.entity.GlossaryTermChangeEvent; import com.linkedin.metadata.timeline.data.entity.TagChangeEvent; import com.linkedin.schema.SchemaField; +import java.util.ArrayList; import java.util.Arrays; import java.util.List; import java.util.stream.Collectors; @@ -95,5 +98,27 @@ public static List convertEntityGlossaryTermChangeEvents( .collect(Collectors.toList()); } + public static List generateChangeEvents( + @Nonnull EntityChangeEventGeneratorRegistry entityChangeEventGeneratorRegistry, + @Nonnull final Urn urn, + @Nonnull final String entityName, + @Nonnull final String aspectName, + @Nonnull final Aspect from, + @Nonnull final Aspect to, + @Nonnull AuditStamp auditStamp) { + final List> entityChangeEventGenerators = + entityChangeEventGeneratorRegistry.getEntityChangeEventGenerators(aspectName).stream() + // Note: Assumes that correct types have been registered for the aspect. + .map(changeEventGenerator -> (EntityChangeEventGenerator) changeEventGenerator) + .collect(Collectors.toList()); + final List allChangeEvents = new ArrayList<>(); + for (EntityChangeEventGenerator entityChangeEventGenerator : entityChangeEventGenerators) { + allChangeEvents.addAll( + entityChangeEventGenerator.getChangeEvents( + urn, entityName, aspectName, from, to, auditStamp)); + } + return allChangeEvents; + } + private ChangeEventGeneratorUtils() {} } diff --git a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/DatasetPropertiesChangeEventGenerator.java b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/DatasetPropertiesChangeEventGenerator.java index f9e1d5c835c60c..4f6ebd36829fad 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/DatasetPropertiesChangeEventGenerator.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/DatasetPropertiesChangeEventGenerator.java @@ -4,7 +4,6 @@ import static com.linkedin.metadata.timeline.eventgenerator.EditableDatasetPropertiesChangeEventGenerator.*; import com.datahub.util.RecordUtils; -import com.github.fge.jsonpatch.JsonPatch; import com.google.common.collect.ImmutableMap; import com.linkedin.common.AuditStamp; import com.linkedin.common.urn.Urn; @@ -15,6 +14,7 @@ import com.linkedin.metadata.timeline.data.ChangeOperation; import com.linkedin.metadata.timeline.data.ChangeTransaction; import com.linkedin.metadata.timeline.data.SemanticChangeType; +import jakarta.json.JsonPatch; import java.util.ArrayList; import java.util.Comparator; import java.util.List; diff --git a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/EditableDatasetPropertiesChangeEventGenerator.java b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/EditableDatasetPropertiesChangeEventGenerator.java index 4b112b15792fea..3dee36628b731b 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/EditableDatasetPropertiesChangeEventGenerator.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/EditableDatasetPropertiesChangeEventGenerator.java @@ -3,7 +3,6 @@ import static com.linkedin.metadata.Constants.*; import com.datahub.util.RecordUtils; -import com.github.fge.jsonpatch.JsonPatch; import com.google.common.collect.ImmutableMap; import com.linkedin.common.AuditStamp; import com.linkedin.common.urn.Urn; @@ -14,6 +13,7 @@ import com.linkedin.metadata.timeline.data.ChangeOperation; import com.linkedin.metadata.timeline.data.ChangeTransaction; import com.linkedin.metadata.timeline.data.SemanticChangeType; +import jakarta.json.JsonPatch; import java.util.ArrayList; import java.util.Comparator; import java.util.List; diff --git a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/EditableSchemaMetadataChangeEventGenerator.java b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/EditableSchemaMetadataChangeEventGenerator.java index 4850fde426f002..f244053e8a1f10 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/EditableSchemaMetadataChangeEventGenerator.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/EditableSchemaMetadataChangeEventGenerator.java @@ -4,7 +4,6 @@ import static com.linkedin.metadata.timeline.eventgenerator.ChangeEventGeneratorUtils.*; import com.datahub.util.RecordUtils; -import com.github.fge.jsonpatch.JsonPatch; import com.google.common.collect.ImmutableMap; import com.linkedin.common.AuditStamp; import com.linkedin.common.GlobalTags; @@ -20,6 +19,7 @@ import com.linkedin.schema.EditableSchemaFieldInfo; import com.linkedin.schema.EditableSchemaFieldInfoArray; import com.linkedin.schema.EditableSchemaMetadata; +import jakarta.json.JsonPatch; import java.util.ArrayList; import java.util.Collections; import java.util.Comparator; diff --git a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/EntityChangeEventGenerator.java b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/EntityChangeEventGenerator.java index ff6361981f5100..0afb06a5095f05 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/EntityChangeEventGenerator.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/EntityChangeEventGenerator.java @@ -1,6 +1,5 @@ package com.linkedin.metadata.timeline.eventgenerator; -import com.github.fge.jsonpatch.JsonPatch; import com.linkedin.common.AuditStamp; import com.linkedin.common.urn.Urn; import com.linkedin.data.template.RecordTemplate; @@ -8,6 +7,7 @@ import com.linkedin.metadata.timeline.data.ChangeCategory; import com.linkedin.metadata.timeline.data.ChangeEvent; import com.linkedin.metadata.timeline.data.ChangeTransaction; +import jakarta.json.JsonPatch; import java.util.List; import javax.annotation.Nonnull; diff --git a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/GlobalTagsChangeEventGenerator.java b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/GlobalTagsChangeEventGenerator.java index ef40c5dc81a3c7..a98593750548d3 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/GlobalTagsChangeEventGenerator.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/GlobalTagsChangeEventGenerator.java @@ -3,7 +3,6 @@ import static com.linkedin.metadata.Constants.*; import com.datahub.util.RecordUtils; -import com.github.fge.jsonpatch.JsonPatch; import com.linkedin.common.AuditStamp; import com.linkedin.common.GlobalTags; import com.linkedin.common.TagAssociation; @@ -16,6 +15,7 @@ import com.linkedin.metadata.timeline.data.ChangeTransaction; import com.linkedin.metadata.timeline.data.SemanticChangeType; import com.linkedin.metadata.timeline.data.entity.TagChangeEvent; +import jakarta.json.JsonPatch; import java.util.ArrayList; import java.util.Comparator; import java.util.List; diff --git a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/GlossaryTermInfoChangeEventGenerator.java b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/GlossaryTermInfoChangeEventGenerator.java index eb002a9a83ceab..8b6ae1f4e7ef00 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/GlossaryTermInfoChangeEventGenerator.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/GlossaryTermInfoChangeEventGenerator.java @@ -4,7 +4,6 @@ import static com.linkedin.metadata.timeline.eventgenerator.EditableDatasetPropertiesChangeEventGenerator.*; import com.datahub.util.RecordUtils; -import com.github.fge.jsonpatch.JsonPatch; import com.linkedin.common.AuditStamp; import com.linkedin.common.urn.Urn; import com.linkedin.glossary.GlossaryTermInfo; @@ -14,6 +13,7 @@ import com.linkedin.metadata.timeline.data.ChangeOperation; import com.linkedin.metadata.timeline.data.ChangeTransaction; import com.linkedin.metadata.timeline.data.SemanticChangeType; +import jakarta.json.JsonPatch; import java.util.ArrayList; import java.util.Comparator; import java.util.List; diff --git a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/GlossaryTermsChangeEventGenerator.java b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/GlossaryTermsChangeEventGenerator.java index 6e56a7e7bbeb17..4e2110a6e35c14 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/GlossaryTermsChangeEventGenerator.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/GlossaryTermsChangeEventGenerator.java @@ -3,7 +3,6 @@ import static com.linkedin.metadata.Constants.*; import com.datahub.util.RecordUtils; -import com.github.fge.jsonpatch.JsonPatch; import com.linkedin.common.AuditStamp; import com.linkedin.common.GlossaryTermAssociation; import com.linkedin.common.GlossaryTermAssociationArray; @@ -16,6 +15,7 @@ import com.linkedin.metadata.timeline.data.ChangeTransaction; import com.linkedin.metadata.timeline.data.SemanticChangeType; import com.linkedin.metadata.timeline.data.entity.GlossaryTermChangeEvent; +import jakarta.json.JsonPatch; import java.util.ArrayList; import java.util.Comparator; import java.util.List; diff --git a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/InstitutionalMemoryChangeEventGenerator.java b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/InstitutionalMemoryChangeEventGenerator.java index bf3ff3293d2a21..6d5ff2abadf014 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/InstitutionalMemoryChangeEventGenerator.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/InstitutionalMemoryChangeEventGenerator.java @@ -3,7 +3,6 @@ import static com.linkedin.metadata.Constants.*; import com.datahub.util.RecordUtils; -import com.github.fge.jsonpatch.JsonPatch; import com.linkedin.common.AuditStamp; import com.linkedin.common.InstitutionalMemory; import com.linkedin.common.InstitutionalMemoryMetadata; @@ -16,6 +15,7 @@ import com.linkedin.metadata.timeline.data.ChangeOperation; import com.linkedin.metadata.timeline.data.ChangeTransaction; import com.linkedin.metadata.timeline.data.SemanticChangeType; +import jakarta.json.JsonPatch; import java.util.ArrayList; import java.util.Comparator; import java.util.List; diff --git a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/OwnershipChangeEventGenerator.java b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/OwnershipChangeEventGenerator.java index 1ef5d0f20da5a9..3a66d5d8f016da 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/OwnershipChangeEventGenerator.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/OwnershipChangeEventGenerator.java @@ -3,7 +3,6 @@ import static com.linkedin.metadata.Constants.*; import com.datahub.util.RecordUtils; -import com.github.fge.jsonpatch.JsonPatch; import com.linkedin.common.AuditStamp; import com.linkedin.common.Owner; import com.linkedin.common.OwnerArray; @@ -16,6 +15,7 @@ import com.linkedin.metadata.timeline.data.ChangeTransaction; import com.linkedin.metadata.timeline.data.SemanticChangeType; import com.linkedin.metadata.timeline.data.entity.OwnerChangeEvent; +import jakarta.json.JsonPatch; import java.util.ArrayList; import java.util.Comparator; import java.util.List; diff --git a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/SchemaMetadataChangeEventGenerator.java b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/SchemaMetadataChangeEventGenerator.java index 483ab806c84622..129a42c0775d7c 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/SchemaMetadataChangeEventGenerator.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/SchemaMetadataChangeEventGenerator.java @@ -3,7 +3,6 @@ import static com.linkedin.metadata.timeline.eventgenerator.ChangeEventGeneratorUtils.*; import com.datahub.util.RecordUtils; -import com.github.fge.jsonpatch.JsonPatch; import com.google.common.collect.ImmutableMap; import com.linkedin.common.AuditStamp; import com.linkedin.common.urn.DatasetUrn; @@ -19,6 +18,7 @@ import com.linkedin.schema.SchemaField; import com.linkedin.schema.SchemaFieldArray; import com.linkedin.schema.SchemaMetadata; +import jakarta.json.JsonPatch; import java.net.URISyntaxException; import java.util.ArrayList; import java.util.Collections; diff --git a/metadata-io/src/test/java/com/linkedin/metadata/schemafields/sideeffects/SchemaFieldSideEffectTest.java b/metadata-io/src/test/java/com/linkedin/metadata/schemafields/sideeffects/SchemaFieldSideEffectTest.java new file mode 100644 index 00000000000000..6139776702c715 --- /dev/null +++ b/metadata-io/src/test/java/com/linkedin/metadata/schemafields/sideeffects/SchemaFieldSideEffectTest.java @@ -0,0 +1,713 @@ +package com.linkedin.metadata.schemafields.sideeffects; + +import static com.linkedin.metadata.Constants.DATASET_ENTITY_NAME; +import static com.linkedin.metadata.Constants.DATASET_KEY_ASPECT_NAME; +import static com.linkedin.metadata.Constants.SCHEMA_FIELD_ALIASES_ASPECT; +import static com.linkedin.metadata.Constants.SCHEMA_FIELD_ENTITY_NAME; +import static com.linkedin.metadata.Constants.SCHEMA_FIELD_KEY_ASPECT; +import static com.linkedin.metadata.Constants.SCHEMA_METADATA_ASPECT_NAME; +import static com.linkedin.metadata.Constants.STATUS_ASPECT_NAME; +import static org.mockito.ArgumentMatchers.anySet; +import static org.mockito.ArgumentMatchers.eq; +import static org.mockito.Mockito.mock; +import static org.mockito.Mockito.reset; +import static org.mockito.Mockito.when; +import static org.testng.Assert.assertEquals; + +import com.linkedin.common.Status; +import com.linkedin.common.UrnArray; +import com.linkedin.common.urn.Urn; +import com.linkedin.common.urn.UrnUtils; +import com.linkedin.data.ByteString; +import com.linkedin.entity.Aspect; +import com.linkedin.events.metadata.ChangeType; +import com.linkedin.metadata.aspect.AspectRetriever; +import com.linkedin.metadata.aspect.batch.MCLItem; +import com.linkedin.metadata.aspect.batch.MCPItem; +import com.linkedin.metadata.aspect.plugins.config.AspectPluginConfig; +import com.linkedin.metadata.entity.SearchRetriever; +import com.linkedin.metadata.entity.ebean.batch.ChangeItemImpl; +import com.linkedin.metadata.entity.ebean.batch.DeleteItemImpl; +import com.linkedin.metadata.entity.ebean.batch.MCLItemImpl; +import com.linkedin.metadata.models.AspectSpec; +import com.linkedin.metadata.models.registry.EntityRegistry; +import com.linkedin.metadata.timeline.eventgenerator.EntityChangeEventGeneratorRegistry; +import com.linkedin.metadata.timeline.eventgenerator.EntityKeyChangeEventGenerator; +import com.linkedin.metadata.timeline.eventgenerator.SchemaMetadataChangeEventGenerator; +import com.linkedin.metadata.timeline.eventgenerator.StatusChangeEventGenerator; +import com.linkedin.metadata.utils.AuditStampUtils; +import com.linkedin.metadata.utils.GenericRecordUtils; +import com.linkedin.metadata.utils.SystemMetadataUtils; +import com.linkedin.mxe.MetadataChangeLog; +import com.linkedin.mxe.MetadataChangeProposal; +import com.linkedin.mxe.SystemMetadata; +import com.linkedin.schema.SchemaMetadata; +import com.linkedin.schemafield.SchemaFieldAliases; +import com.linkedin.test.metadata.aspect.TestEntityRegistry; +import com.linkedin.test.metadata.aspect.batch.TestMCP; +import io.datahubproject.metadata.context.RetrieverContext; +import io.datahubproject.test.metadata.context.TestOperationContexts; +import java.nio.charset.StandardCharsets; +import java.util.ArrayList; +import java.util.List; +import java.util.Map; +import java.util.Set; +import java.util.stream.Collectors; +import org.testng.annotations.BeforeMethod; +import org.testng.annotations.Test; + +public class SchemaFieldSideEffectTest { + private static final EntityRegistry TEST_REGISTRY = new TestEntityRegistry(); + private static final List SUPPORTED_CHANGE_TYPES = + List.of( + ChangeType.CREATE, + ChangeType.CREATE_ENTITY, + ChangeType.UPSERT, + ChangeType.DELETE, + ChangeType.RESTATE); + private static final Urn TEST_URN = + UrnUtils.getUrn("urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD)"); + private static final AspectPluginConfig TEST_PLUGIN_CONFIG = + AspectPluginConfig.builder() + .className(SchemaFieldSideEffect.class.getName()) + .enabled(true) + .supportedOperations( + SUPPORTED_CHANGE_TYPES.stream() + .map(ChangeType::toString) + .collect(Collectors.toList())) + .supportedEntityAspectNames( + List.of( + AspectPluginConfig.EntityAspectName.builder() + .entityName(DATASET_ENTITY_NAME) + .aspectName(SCHEMA_METADATA_ASPECT_NAME) + .build(), + AspectPluginConfig.EntityAspectName.builder() + .entityName(DATASET_ENTITY_NAME) + .aspectName(STATUS_ASPECT_NAME) + .build())) + .build(); + + private AspectRetriever mockAspectRetriever; + private RetrieverContext retrieverContext; + + @BeforeMethod + public void setup() { + mockAspectRetriever = mock(AspectRetriever.class); + when(mockAspectRetriever.getEntityRegistry()).thenReturn(TEST_REGISTRY); + retrieverContext = + RetrieverContext.builder() + .searchRetriever(mock(SearchRetriever.class)) + .aspectRetriever(mockAspectRetriever) + .graphRetriever(TestOperationContexts.emptyGraphRetriever) + .build(); + } + + @Test + public void schemaMetadataToSchemaFieldKeyTest() { + SchemaFieldSideEffect test = new SchemaFieldSideEffect(); + test.setConfig(TEST_PLUGIN_CONFIG); + SchemaMetadata schemaMetadata = getTestSchemaMetadata(); + + List testOutput; + for (ChangeType changeType : + List.of(ChangeType.CREATE, ChangeType.CREATE_ENTITY, ChangeType.UPSERT)) { + // Run test + ChangeItemImpl schemaMetadataChangeItem = + ChangeItemImpl.builder() + .urn(TEST_URN) + .aspectName(SCHEMA_METADATA_ASPECT_NAME) + .changeType(changeType) + .entitySpec(TEST_REGISTRY.getEntitySpec(DATASET_ENTITY_NAME)) + .aspectSpec( + TEST_REGISTRY + .getEntitySpec(DATASET_ENTITY_NAME) + .getAspectSpec(SCHEMA_METADATA_ASPECT_NAME)) + .recordTemplate(schemaMetadata) + .auditStamp(AuditStampUtils.createDefaultAuditStamp()) + .build(mockAspectRetriever); + testOutput = + test.postMCPSideEffect( + List.of( + MCLItemImpl.builder() + .build( + schemaMetadataChangeItem, + null, + null, + retrieverContext.getAspectRetriever())), + retrieverContext) + .toList(); + + // Verify test + switch (changeType) { + default -> { + assertEquals( + testOutput.size(), 2, "Unexpected output items for changeType:" + changeType); + + assertEquals( + testOutput, + List.of( + ChangeItemImpl.builder() + .urn( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_id)")) + .aspectName(SCHEMA_FIELD_ALIASES_ASPECT) + .changeType(changeType) + .entitySpec(TEST_REGISTRY.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)) + .aspectSpec( + TEST_REGISTRY + .getEntitySpec(SCHEMA_FIELD_ENTITY_NAME) + .getAspectSpec(SCHEMA_FIELD_ALIASES_ASPECT)) + .recordTemplate( + new SchemaFieldAliases() + .setAliases( + new UrnArray( + List.of( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_id)"))))) + .auditStamp(schemaMetadataChangeItem.getAuditStamp()) + .systemMetadata(schemaMetadataChangeItem.getSystemMetadata()) + .build(mockAspectRetriever), + ChangeItemImpl.builder() + .urn( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_name)")) + .aspectName(SCHEMA_FIELD_ALIASES_ASPECT) + .changeType(changeType) + .entitySpec(TEST_REGISTRY.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)) + .aspectSpec( + TEST_REGISTRY + .getEntitySpec(SCHEMA_FIELD_ENTITY_NAME) + .getAspectSpec(SCHEMA_FIELD_ALIASES_ASPECT)) + .recordTemplate( + new SchemaFieldAliases() + .setAliases( + new UrnArray( + List.of( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_name)"))))) + .auditStamp(schemaMetadataChangeItem.getAuditStamp()) + .systemMetadata(schemaMetadataChangeItem.getSystemMetadata()) + .build(mockAspectRetriever))); + } + } + } + } + + @Test + public void statusToSchemaFieldStatusTest() { + SchemaFieldSideEffect test = new SchemaFieldSideEffect(); + test.setConfig(TEST_PLUGIN_CONFIG); + SchemaMetadata schemaMetadata = getTestSchemaMetadata(); + Status status = new Status().setRemoved(true); + + // Case 1. schemaMetadata (exists), then status updated + reset(mockAspectRetriever); + when(mockAspectRetriever.getEntityRegistry()).thenReturn(TEST_REGISTRY); + when(mockAspectRetriever.getLatestAspectObjects( + Set.of(TEST_URN), Set.of(SCHEMA_METADATA_ASPECT_NAME))) + .thenReturn( + Map.of( + TEST_URN, Map.of(SCHEMA_METADATA_ASPECT_NAME, new Aspect(schemaMetadata.data())))); + + List testOutput; + for (ChangeType changeType : List.of(ChangeType.CREATE, ChangeType.UPSERT)) { + // Run Status test + ChangeItemImpl statusChangeItem = + ChangeItemImpl.builder() + .urn(TEST_URN) + .aspectName(STATUS_ASPECT_NAME) + .changeType(changeType) + .entitySpec(TEST_REGISTRY.getEntitySpec(DATASET_ENTITY_NAME)) + .aspectSpec( + TEST_REGISTRY + .getEntitySpec(DATASET_ENTITY_NAME) + .getAspectSpec(STATUS_ASPECT_NAME)) + .recordTemplate(status) + .auditStamp(AuditStampUtils.createDefaultAuditStamp()) + .build(mockAspectRetriever); + testOutput = + test.postMCPSideEffect( + List.of( + MCLItemImpl.builder() + .build( + statusChangeItem, null, null, retrieverContext.getAspectRetriever())), + retrieverContext) + .collect(Collectors.toList()); + + // Verify test + switch (changeType) { + default -> { + assertEquals( + testOutput.size(), 2, "Unexpected output items for changeType:" + changeType); + + assertEquals( + testOutput, + List.of( + ChangeItemImpl.builder() + .urn( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_id)")) + .aspectName(STATUS_ASPECT_NAME) + .changeType(changeType) + .entitySpec(TEST_REGISTRY.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)) + .aspectSpec( + TEST_REGISTRY + .getEntitySpec(SCHEMA_FIELD_ENTITY_NAME) + .getAspectSpec(STATUS_ASPECT_NAME)) + .recordTemplate(status) + .auditStamp(statusChangeItem.getAuditStamp()) + .systemMetadata(statusChangeItem.getSystemMetadata()) + .build(mockAspectRetriever), + ChangeItemImpl.builder() + .urn( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_name)")) + .aspectName(STATUS_ASPECT_NAME) + .changeType(changeType) + .entitySpec(TEST_REGISTRY.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)) + .aspectSpec( + TEST_REGISTRY + .getEntitySpec(SCHEMA_FIELD_ENTITY_NAME) + .getAspectSpec(STATUS_ASPECT_NAME)) + .recordTemplate(status) + .auditStamp(statusChangeItem.getAuditStamp()) + .systemMetadata(statusChangeItem.getSystemMetadata()) + .build(mockAspectRetriever))); + } + } + } + + // Case 2. status (exists), then schemaMetadata + reset(mockAspectRetriever); + when(mockAspectRetriever.getEntityRegistry()).thenReturn(TEST_REGISTRY); + when(mockAspectRetriever.getLatestAspectObjects(Set.of(TEST_URN), Set.of(STATUS_ASPECT_NAME))) + .thenReturn(Map.of(TEST_URN, Map.of(STATUS_ASPECT_NAME, new Aspect(status.data())))); + + for (ChangeType changeType : List.of(ChangeType.CREATE, ChangeType.UPSERT)) { + // Run test + ChangeItemImpl schemaMetadataChangeItem = + ChangeItemImpl.builder() + .urn(TEST_URN) + .aspectName(SCHEMA_METADATA_ASPECT_NAME) + .changeType(changeType) + .entitySpec(TEST_REGISTRY.getEntitySpec(DATASET_ENTITY_NAME)) + .aspectSpec( + TEST_REGISTRY + .getEntitySpec(DATASET_ENTITY_NAME) + .getAspectSpec(SCHEMA_METADATA_ASPECT_NAME)) + .recordTemplate(schemaMetadata) + .auditStamp(AuditStampUtils.createDefaultAuditStamp()) + .build(mockAspectRetriever); + testOutput = + test.postMCPSideEffect( + List.of( + MCLItemImpl.builder() + .build( + schemaMetadataChangeItem, + null, + null, + retrieverContext.getAspectRetriever())), + retrieverContext) + .collect(Collectors.toList()); + + // Verify test + switch (changeType) { + default -> { + assertEquals( + testOutput.size(), 4, "Unexpected output items for changeType:" + changeType); + + assertEquals( + testOutput, + List.of( + ChangeItemImpl.builder() + .urn( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_id)")) + .aspectName(STATUS_ASPECT_NAME) + .changeType(changeType) + .entitySpec(TEST_REGISTRY.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)) + .aspectSpec( + TEST_REGISTRY + .getEntitySpec(SCHEMA_FIELD_ENTITY_NAME) + .getAspectSpec(STATUS_ASPECT_NAME)) + .recordTemplate(status) + .auditStamp(schemaMetadataChangeItem.getAuditStamp()) + .systemMetadata(schemaMetadataChangeItem.getSystemMetadata()) + .build(mockAspectRetriever), + ChangeItemImpl.builder() + .urn( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_name)")) + .aspectName(STATUS_ASPECT_NAME) + .changeType(changeType) + .entitySpec(TEST_REGISTRY.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)) + .aspectSpec( + TEST_REGISTRY + .getEntitySpec(SCHEMA_FIELD_ENTITY_NAME) + .getAspectSpec(STATUS_ASPECT_NAME)) + .recordTemplate(status) + .auditStamp(schemaMetadataChangeItem.getAuditStamp()) + .systemMetadata(schemaMetadataChangeItem.getSystemMetadata()) + .build(mockAspectRetriever), + ChangeItemImpl.builder() + .urn( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_id)")) + .aspectName(SCHEMA_FIELD_ALIASES_ASPECT) + .changeType(changeType) + .entitySpec(TEST_REGISTRY.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)) + .aspectSpec( + TEST_REGISTRY + .getEntitySpec(SCHEMA_FIELD_ENTITY_NAME) + .getAspectSpec(SCHEMA_FIELD_ALIASES_ASPECT)) + .recordTemplate( + new SchemaFieldAliases() + .setAliases( + new UrnArray( + List.of( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_id)"))))) + .auditStamp(schemaMetadataChangeItem.getAuditStamp()) + .systemMetadata(schemaMetadataChangeItem.getSystemMetadata()) + .build(mockAspectRetriever), + ChangeItemImpl.builder() + .urn( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_name)")) + .aspectName(SCHEMA_FIELD_ALIASES_ASPECT) + .changeType(changeType) + .entitySpec(TEST_REGISTRY.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)) + .aspectSpec( + TEST_REGISTRY + .getEntitySpec(SCHEMA_FIELD_ENTITY_NAME) + .getAspectSpec(SCHEMA_FIELD_ALIASES_ASPECT)) + .recordTemplate( + new SchemaFieldAliases() + .setAliases( + new UrnArray( + List.of( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_name)"))))) + .auditStamp(schemaMetadataChangeItem.getAuditStamp()) + .systemMetadata(schemaMetadataChangeItem.getSystemMetadata()) + .build(mockAspectRetriever))); + } + } + } + } + + @Test + public void schemaMetadataDeleteTest() { + SchemaFieldSideEffect test = new SchemaFieldSideEffect(); + test.setConfig(TEST_PLUGIN_CONFIG); + SchemaMetadata schemaMetadata = getTestSchemaMetadata(); + + // Run test + MCLItem schemaMetadataChangeItem = + MCLItemImpl.builder() + .metadataChangeLog( + new MetadataChangeLog() + .setChangeType(ChangeType.DELETE) + .setEntityUrn(TEST_URN) + .setEntityType(DATASET_ENTITY_NAME) + .setAspectName(SCHEMA_METADATA_ASPECT_NAME) + .setPreviousAspectValue(GenericRecordUtils.serializeAspect(schemaMetadata)) + .setCreated(AuditStampUtils.createDefaultAuditStamp())) + .build(retrieverContext.getAspectRetriever()); + + List testOutput = + test.postMCPSideEffect(List.of(schemaMetadataChangeItem), retrieverContext).toList(); + + List expectedEveryAspectPerField = new ArrayList<>(); + for (String schemaField : + List.of( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_id)", + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_name)")) { + for (AspectSpec aspectSpec : + TEST_REGISTRY.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME).getAspectSpecs()) { + expectedEveryAspectPerField.add( + DeleteItemImpl.builder() + .urn(UrnUtils.getUrn(schemaField)) + .aspectName(aspectSpec.getName()) + .auditStamp(schemaMetadataChangeItem.getAuditStamp()) + .entitySpec(TEST_REGISTRY.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)) + .aspectSpec(aspectSpec) + .build(retrieverContext.getAspectRetriever())); + } + } + + assertEquals( + testOutput.size(), + expectedEveryAspectPerField.size(), + "Unexpected output items for changeType:" + ChangeType.DELETE); + assertEquals( + testOutput.stream() + .filter(item -> item.getAspectName().equals(SCHEMA_FIELD_KEY_ASPECT)) + .count(), + 2, + "Expected both key aspects"); + + assertEquals(testOutput, expectedEveryAspectPerField); + } + + @Test + public void statusDeleteTest() { + SchemaFieldSideEffect test = new SchemaFieldSideEffect(); + test.setConfig(TEST_PLUGIN_CONFIG); + Status status = new Status().setRemoved(false); + + // mock response + reset(mockAspectRetriever); + when(mockAspectRetriever.getEntityRegistry()).thenReturn(TEST_REGISTRY); + when(mockAspectRetriever.getLatestAspectObjects(eq(Set.of(TEST_URN)), anySet())) + .thenReturn( + Map.of( + TEST_URN, + Map.of(SCHEMA_METADATA_ASPECT_NAME, new Aspect(getTestSchemaMetadata().data())))); + + // Run test + MCLItem statusChangeItem = + MCLItemImpl.builder() + .metadataChangeLog( + new MetadataChangeLog() + .setChangeType(ChangeType.DELETE) + .setEntityUrn(TEST_URN) + .setEntityType(DATASET_ENTITY_NAME) + .setAspectName(STATUS_ASPECT_NAME) + .setPreviousAspectValue(GenericRecordUtils.serializeAspect(status)) + .setCreated(AuditStampUtils.createDefaultAuditStamp())) + .build(retrieverContext.getAspectRetriever()); + + List testOutput = + test.postMCPSideEffect(List.of(statusChangeItem), retrieverContext).toList(); + + List expectedStatusDeletePerField = new ArrayList<>(); + for (String schemaField : + List.of( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_id)", + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_name)")) { + for (AspectSpec aspectSpec : + List.of( + TEST_REGISTRY + .getEntitySpec(SCHEMA_FIELD_ENTITY_NAME) + .getAspectSpec(STATUS_ASPECT_NAME))) { + expectedStatusDeletePerField.add( + DeleteItemImpl.builder() + .urn(UrnUtils.getUrn(schemaField)) + .aspectName(aspectSpec.getName()) + .auditStamp(statusChangeItem.getAuditStamp()) + .entitySpec(TEST_REGISTRY.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)) + .aspectSpec(aspectSpec) + .build(retrieverContext.getAspectRetriever())); + } + } + + assertEquals( + testOutput.size(), + expectedStatusDeletePerField.size(), + "Unexpected output items for changeType:" + ChangeType.DELETE); + assertEquals( + testOutput.stream().filter(item -> item.getAspectName().equals(STATUS_ASPECT_NAME)).count(), + 2, + "Expected both status aspects"); + assertEquals(testOutput, expectedStatusDeletePerField); + } + + @Test + public void schemaMetadataRemovedFieldTest() { + SchemaFieldSideEffect test = new SchemaFieldSideEffect(); + test.setConfig(TEST_PLUGIN_CONFIG); + test.setEntityChangeEventGeneratorRegistry(buildEntityChangeEventGeneratorRegistry()); + + SchemaMetadata previousSchemaMetadata = getTestSchemaMetadata(); + SchemaMetadata currentSchemaMetadata = getTestSchemaMetadataWithRemovedField(); + + List testOutput; + for (ChangeType changeType : List.of(ChangeType.UPSERT)) { + // Run test + ChangeItemImpl schemaMetadataChangeItem = + ChangeItemImpl.builder() + .urn(TEST_URN) + .aspectName(SCHEMA_METADATA_ASPECT_NAME) + .changeType(changeType) + .entitySpec(TEST_REGISTRY.getEntitySpec(DATASET_ENTITY_NAME)) + .aspectSpec( + TEST_REGISTRY + .getEntitySpec(DATASET_ENTITY_NAME) + .getAspectSpec(SCHEMA_METADATA_ASPECT_NAME)) + .recordTemplate(currentSchemaMetadata) + .auditStamp(AuditStampUtils.createDefaultAuditStamp()) + .build(mockAspectRetriever); + testOutput = + test.postMCPSideEffect( + List.of( + MCLItemImpl.builder() + .build( + schemaMetadataChangeItem, + // populate previous item with the now removed field + previousSchemaMetadata, + null, + retrieverContext.getAspectRetriever())), + retrieverContext) + .toList(); + + // Verify test + switch (changeType) { + default -> { + assertEquals( + testOutput.size(), 1, "Unexpected output items for changeType:" + changeType); + + assertEquals( + testOutput, + List.of( + ChangeItemImpl.builder() + .urn( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_name)")) + .aspectName(STATUS_ASPECT_NAME) + .changeType(changeType) + .entitySpec(TEST_REGISTRY.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)) + .aspectSpec( + TEST_REGISTRY + .getEntitySpec(SCHEMA_FIELD_ENTITY_NAME) + .getAspectSpec(STATUS_ASPECT_NAME)) + .recordTemplate(new Status().setRemoved(true)) + .auditStamp(schemaMetadataChangeItem.getAuditStamp()) + .systemMetadata(schemaMetadataChangeItem.getSystemMetadata()) + .build(mockAspectRetriever))); + } + } + } + } + + private static SchemaMetadata getTestSchemaMetadata() { + String rawSchemaMetadataString = + "{\"foreignKeys\":[{\"name\":\"user id\",\"sourceFields\":[\"urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_id)\"],\"foreignFields\":[\"urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_deleted,PROD),user_id)\"],\"foreignDataset\":\"urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_deleted,PROD)\"}],\"platformSchema\":{\"com.linkedin.schema.KafkaSchema\":{\"documentSchemaType\":\"AVRO\",\"documentSchema\":\"{\\\"type\\\":\\\"record\\\",\\\"name\\\":\\\"SampleHiveSchema\\\",\\\"namespace\\\":\\\"com.linkedin.dataset\\\",\\\"doc\\\":\\\"Sample Hive dataset\\\",\\\"fields\\\":[{\\\"name\\\":\\\"field_foo\\\",\\\"type\\\":[\\\"string\\\"]},{\\\"name\\\":\\\"field_bar\\\",\\\"type\\\":[\\\"boolean\\\"]}]}\"}},\"created\":{\"actor\":\"urn:li:corpuser:jdoe\",\"time\":1674291843000},\"lastModified\":{\"actor\":\"urn:li:corpuser:jdoe\",\"time\":1674291843000},\"fields\":[{\"nullable\":false,\"fieldPath\":\"user_id\",\"description\":\"Id of the user created\",\"isPartOfKey\":false,\"type\":{\"type\":{\"com.linkedin.schema.BooleanType\":{}}},\"recursive\":false,\"nativeDataType\":\"varchar(100)\"},{\"nullable\":false,\"fieldPath\":\"user_name\",\"description\":\"Name of the user who signed up\",\"isPartOfKey\":false,\"type\":{\"type\":{\"com.linkedin.schema.BooleanType\":{}}},\"recursive\":false,\"nativeDataType\":\"boolean\"}],\"schemaName\":\"SampleHiveSchema\",\"version\":0,\"hash\":\"\",\"platform\":\"urn:li:dataPlatform:hive\"}"; + ByteString rawSchemaMetadataBytes = + ByteString.copyString(rawSchemaMetadataString, StandardCharsets.UTF_8); + return GenericRecordUtils.deserializeAspect( + rawSchemaMetadataBytes, "application/json", SchemaMetadata.class); + } + + private static SchemaMetadata getTestSchemaMetadataWithRemovedField() { + String rawSchemaMetadataString = + "{\"foreignKeys\":[{\"name\":\"user id\",\"sourceFields\":[\"urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_id)\"],\"foreignFields\":[\"urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_deleted,PROD),user_id)\"],\"foreignDataset\":\"urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_deleted,PROD)\"}],\"platformSchema\":{\"com.linkedin.schema.KafkaSchema\":{\"documentSchemaType\":\"AVRO\",\"documentSchema\":\"{\\\"type\\\":\\\"record\\\",\\\"name\\\":\\\"SampleHiveSchema\\\",\\\"namespace\\\":\\\"com.linkedin.dataset\\\",\\\"doc\\\":\\\"Sample Hive dataset\\\",\\\"fields\\\":[{\\\"name\\\":\\\"field_foo\\\",\\\"type\\\":[\\\"string\\\"]},{\\\"name\\\":\\\"field_bar\\\",\\\"type\\\":[\\\"boolean\\\"]}]}\"}},\"created\":{\"actor\":\"urn:li:corpuser:jdoe\",\"time\":1674291843000},\"lastModified\":{\"actor\":\"urn:li:corpuser:jdoe\",\"time\":1674291843000},\"fields\":[{\"nullable\":false,\"fieldPath\":\"user_id\",\"description\":\"Id of the user created\",\"isPartOfKey\":false,\"type\":{\"type\":{\"com.linkedin.schema.BooleanType\":{}}},\"recursive\":false,\"nativeDataType\":\"varchar(100)\"}],\"schemaName\":\"SampleHiveSchema\",\"version\":0,\"hash\":\"\",\"platform\":\"urn:li:dataPlatform:hive\"}"; + ByteString rawSchemaMetadataBytes = + ByteString.copyString(rawSchemaMetadataString, StandardCharsets.UTF_8); + return GenericRecordUtils.deserializeAspect( + rawSchemaMetadataBytes, "application/json", SchemaMetadata.class); + } + + private static EntityChangeEventGeneratorRegistry buildEntityChangeEventGeneratorRegistry() { + final EntityChangeEventGeneratorRegistry registry = new EntityChangeEventGeneratorRegistry(); + registry.register(SCHEMA_METADATA_ASPECT_NAME, new SchemaMetadataChangeEventGenerator()); + + // Entity Lifecycle change event generators + registry.register(DATASET_KEY_ASPECT_NAME, new EntityKeyChangeEventGenerator<>()); + registry.register(STATUS_ASPECT_NAME, new StatusChangeEventGenerator()); + + return registry; + } + + @Test + public void schemaMetadataRestateAliasesTest() throws CloneNotSupportedException { + SchemaFieldSideEffect test = new SchemaFieldSideEffect(); + test.setEntityChangeEventGeneratorRegistry(mock(EntityChangeEventGeneratorRegistry.class)); + test.setConfig(TEST_PLUGIN_CONFIG); + SchemaMetadata schemaMetadata = getTestSchemaMetadata(); + + List testOutput; + for (ChangeType changeType : List.of(ChangeType.RESTATE)) { + // Run test with RESTATE MCP + SystemMetadata systemMetadata = SystemMetadataUtils.createDefaultSystemMetadata(); + MetadataChangeProposal restateMCP = + new MetadataChangeProposal() + .setEntityUrn(TEST_URN) + .setChangeType(changeType) + .setAspectName(SCHEMA_METADATA_ASPECT_NAME) + .setEntityType(TEST_URN.getEntityType()) + .setSystemMetadata(systemMetadata) + .setAspect(GenericRecordUtils.serializeAspect(schemaMetadata)); + + MCPItem schemaMetadataChangeItem = + TestMCP.builder() + .urn(TEST_URN) + .metadataChangeProposal(restateMCP) + .entitySpec(TEST_REGISTRY.getEntitySpec(DATASET_ENTITY_NAME)) + .changeType(changeType) + .aspectSpec( + TEST_REGISTRY + .getEntitySpec(DATASET_ENTITY_NAME) + .getAspectSpec(SCHEMA_METADATA_ASPECT_NAME)) + .auditStamp(AuditStampUtils.createDefaultAuditStamp()) + .systemMetadata(systemMetadata) + .build(); + + testOutput = + test.postMCPSideEffect( + List.of( + MCLItemImpl.builder() + .build( + schemaMetadataChangeItem, + schemaMetadata, + schemaMetadataChangeItem.getSystemMetadata(), + retrieverContext.getAspectRetriever())), + retrieverContext) + .toList(); + + // Verify test + switch (changeType) { + default -> { + assertEquals( + testOutput.size(), 2, "Unexpected output items for changeType:" + changeType); + + assertEquals( + testOutput, + List.of( + ChangeItemImpl.builder() + .urn( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_id)")) + .aspectName(SCHEMA_FIELD_ALIASES_ASPECT) + .changeType(ChangeType.UPSERT) + .entitySpec(TEST_REGISTRY.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)) + .aspectSpec( + TEST_REGISTRY + .getEntitySpec(SCHEMA_FIELD_ENTITY_NAME) + .getAspectSpec(SCHEMA_FIELD_ALIASES_ASPECT)) + .recordTemplate( + new SchemaFieldAliases() + .setAliases( + new UrnArray( + List.of( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_id)"))))) + .auditStamp(schemaMetadataChangeItem.getAuditStamp()) + .systemMetadata(systemMetadata) + .build(mockAspectRetriever), + ChangeItemImpl.builder() + .urn( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_name)")) + .aspectName(SCHEMA_FIELD_ALIASES_ASPECT) + .changeType(ChangeType.UPSERT) + .entitySpec(TEST_REGISTRY.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)) + .aspectSpec( + TEST_REGISTRY + .getEntitySpec(SCHEMA_FIELD_ENTITY_NAME) + .getAspectSpec(SCHEMA_FIELD_ALIASES_ASPECT)) + .recordTemplate( + new SchemaFieldAliases() + .setAliases( + new UrnArray( + List.of( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:hive,fct_users_created,PROD),user_name)"))))) + .auditStamp(schemaMetadataChangeItem.getAuditStamp()) + .systemMetadata(systemMetadata) + .build(mockAspectRetriever))); + } + } + } + } +} diff --git a/metadata-io/src/test/java/com/linkedin/metadata/search/LineageServiceTestBase.java b/metadata-io/src/test/java/com/linkedin/metadata/search/LineageServiceTestBase.java index 99e4923885a41d..eee0e0d0f2ec6f 100644 --- a/metadata-io/src/test/java/com/linkedin/metadata/search/LineageServiceTestBase.java +++ b/metadata-io/src/test/java/com/linkedin/metadata/search/LineageServiceTestBase.java @@ -27,7 +27,11 @@ import com.linkedin.data.template.LongMap; import com.linkedin.data.template.SetMode; import com.linkedin.metadata.TestEntityUtil; +import com.linkedin.metadata.config.DataHubAppConfiguration; +import com.linkedin.metadata.config.MetadataChangeProposalConfig; +import com.linkedin.metadata.config.cache.CacheConfiguration; import com.linkedin.metadata.config.cache.EntityDocCountCacheConfiguration; +import com.linkedin.metadata.config.cache.SearchCacheConfiguration; import com.linkedin.metadata.config.cache.SearchLineageCacheConfiguration; import com.linkedin.metadata.config.search.SearchConfiguration; import com.linkedin.metadata.config.search.custom.CustomSearchConfiguration; @@ -122,7 +126,11 @@ public void setup() throws RemoteInvocationException, URISyntaxException { operationContext = TestOperationContexts.systemContextNoSearchAuthorization( new SnapshotEntityRegistry(new Snapshot()), - new IndexConventionImpl("lineage_search_service_test", "MD5")) + new IndexConventionImpl( + IndexConventionImpl.IndexConventionConfig.builder() + .prefix("lineage_search_service_test") + .hashIdAlgo("MD5") + .build())) .asSession(RequestContext.TEST, Authorizer.EMPTY, TestOperationContexts.TEST_USER_AUTH); settingsBuilder = new SettingsBuilder(null); elasticSearchService = buildEntitySearchService(); @@ -139,10 +147,25 @@ private void resetService(boolean withCache, boolean withLightingCache) { new EntityDocCountCacheConfiguration(); entityDocCountCacheConfiguration.setTtlSeconds(600L); - SearchLineageCacheConfiguration searchLineageCacheConfiguration = - new SearchLineageCacheConfiguration(); - searchLineageCacheConfiguration.setTtlSeconds(600L); - searchLineageCacheConfiguration.setLightningThreshold(withLightingCache ? -1 : 300); + DataHubAppConfiguration appConfig = new DataHubAppConfiguration(); + appConfig.setCache(new CacheConfiguration()); + appConfig.getCache().setSearch(new SearchCacheConfiguration()); + appConfig.getCache().getSearch().setLineage(new SearchLineageCacheConfiguration()); + appConfig.getCache().getSearch().getLineage().setTtlSeconds(600L); + appConfig + .getCache() + .getSearch() + .getLineage() + .setLightningThreshold(withLightingCache ? -1 : 300); + appConfig.setMetadataChangeProposal(new MetadataChangeProposalConfig()); + appConfig + .getMetadataChangeProposal() + .setSideEffects(new MetadataChangeProposalConfig.SideEffectsConfig()); + appConfig + .getMetadataChangeProposal() + .getSideEffects() + .setSchemaField(new MetadataChangeProposalConfig.SideEffectConfig()); + appConfig.getMetadataChangeProposal().getSideEffects().getSchemaField().setEnabled(false); lineageSearchService = spy( @@ -157,7 +180,7 @@ private void resetService(boolean withCache, boolean withLightingCache) { graphService, cacheManager.getCache("test"), withCache, - searchLineageCacheConfiguration)); + appConfig)); } @BeforeMethod diff --git a/metadata-io/src/test/java/com/linkedin/metadata/search/SearchServiceTestBase.java b/metadata-io/src/test/java/com/linkedin/metadata/search/SearchServiceTestBase.java index 5e30e01a8ea690..1cd0c9550a0fc3 100644 --- a/metadata-io/src/test/java/com/linkedin/metadata/search/SearchServiceTestBase.java +++ b/metadata-io/src/test/java/com/linkedin/metadata/search/SearchServiceTestBase.java @@ -79,7 +79,11 @@ public void setup() throws RemoteInvocationException, URISyntaxException { operationContext = TestOperationContexts.systemContextNoSearchAuthorization( new SnapshotEntityRegistry(new Snapshot()), - new IndexConventionImpl("search_service_test", "MD5")) + new IndexConventionImpl( + IndexConventionImpl.IndexConventionConfig.builder() + .prefix("search_service_test") + .hashIdAlgo("MD5") + .build())) .asSession(RequestContext.TEST, Authorizer.EMPTY, TestOperationContexts.TEST_USER_AUTH); settingsBuilder = new SettingsBuilder(null); diff --git a/metadata-io/src/test/java/com/linkedin/metadata/search/TestEntityTestBase.java b/metadata-io/src/test/java/com/linkedin/metadata/search/TestEntityTestBase.java index 282a3d8e3ea6ae..b04c7d2bc60b92 100644 --- a/metadata-io/src/test/java/com/linkedin/metadata/search/TestEntityTestBase.java +++ b/metadata-io/src/test/java/com/linkedin/metadata/search/TestEntityTestBase.java @@ -63,7 +63,11 @@ public void setup() { opContext = TestOperationContexts.systemContextNoSearchAuthorization( new SnapshotEntityRegistry(new Snapshot()), - new IndexConventionImpl("es_service_test", "MD5")); + new IndexConventionImpl( + IndexConventionImpl.IndexConventionConfig.builder() + .prefix("es_service_test") + .hashIdAlgo("MD5") + .build())); settingsBuilder = new SettingsBuilder(null); elasticSearchService = buildService(); elasticSearchService.reindexAll(Collections.emptySet()); diff --git a/metadata-io/src/test/java/com/linkedin/metadata/search/query/BrowseDAOTest.java b/metadata-io/src/test/java/com/linkedin/metadata/search/query/BrowseDAOTest.java index 8044515e3dc6a7..b71e4ddc54a782 100644 --- a/metadata-io/src/test/java/com/linkedin/metadata/search/query/BrowseDAOTest.java +++ b/metadata-io/src/test/java/com/linkedin/metadata/search/query/BrowseDAOTest.java @@ -45,7 +45,11 @@ public void setup() throws RemoteInvocationException, URISyntaxException { mockClient = mock(RestHighLevelClient.class); opContext = TestOperationContexts.systemContextNoSearchAuthorization( - new IndexConventionImpl("es_browse_dao_test", "MD5")); + new IndexConventionImpl( + IndexConventionImpl.IndexConventionConfig.builder() + .prefix("es_browse_dao_test") + .hashIdAlgo("MD5") + .build())); browseDAO = new ESBrowseDAO(mockClient, searchConfiguration, customSearchConfiguration); } diff --git a/metadata-io/src/test/java/com/linkedin/metadata/systemmetadata/SystemMetadataServiceTestBase.java b/metadata-io/src/test/java/com/linkedin/metadata/systemmetadata/SystemMetadataServiceTestBase.java index 1b9d8c57b4cad3..7cf3fab6e5bb83 100644 --- a/metadata-io/src/test/java/com/linkedin/metadata/systemmetadata/SystemMetadataServiceTestBase.java +++ b/metadata-io/src/test/java/com/linkedin/metadata/systemmetadata/SystemMetadataServiceTestBase.java @@ -32,7 +32,11 @@ public abstract class SystemMetadataServiceTestBase extends AbstractTestNGSpring protected abstract ESIndexBuilder getIndexBuilder(); private final IndexConvention _indexConvention = - new IndexConventionImpl("es_system_metadata_service_test", "MD5"); + new IndexConventionImpl( + IndexConventionImpl.IndexConventionConfig.builder() + .prefix("es_system_metadata_service_test") + .hashIdAlgo("MD5") + .build()); private ElasticSearchSystemMetadataService _client; diff --git a/metadata-io/src/test/java/com/linkedin/metadata/timeseries/search/TimeseriesAspectServiceTestBase.java b/metadata-io/src/test/java/com/linkedin/metadata/timeseries/search/TimeseriesAspectServiceTestBase.java index 414183c8882f9c..6c650e725fd5cf 100644 --- a/metadata-io/src/test/java/com/linkedin/metadata/timeseries/search/TimeseriesAspectServiceTestBase.java +++ b/metadata-io/src/test/java/com/linkedin/metadata/timeseries/search/TimeseriesAspectServiceTestBase.java @@ -126,7 +126,12 @@ public void setup() throws RemoteInvocationException, URISyntaxException { opContext = TestOperationContexts.systemContextNoSearchAuthorization( - entityRegistry, new IndexConventionImpl("es_timeseries_aspect_service_test", "MD5")); + entityRegistry, + new IndexConventionImpl( + IndexConventionImpl.IndexConventionConfig.builder() + .prefix("es_timeseries_aspect_service_test") + .hashIdAlgo("MD5") + .build())); elasticSearchTimeseriesAspectService = buildService(); elasticSearchTimeseriesAspectService.reindexAll(Collections.emptySet()); diff --git a/metadata-io/src/test/java/io/datahubproject/test/fixtures/search/SampleDataFixtureConfiguration.java b/metadata-io/src/test/java/io/datahubproject/test/fixtures/search/SampleDataFixtureConfiguration.java index 6a95d16c254370..20f6084f953299 100644 --- a/metadata-io/src/test/java/io/datahubproject/test/fixtures/search/SampleDataFixtureConfiguration.java +++ b/metadata-io/src/test/java/io/datahubproject/test/fixtures/search/SampleDataFixtureConfiguration.java @@ -86,12 +86,20 @@ protected String longTailIndexPrefix() { @Bean(name = "sampleDataIndexConvention") protected IndexConvention indexConvention(@Qualifier("sampleDataPrefix") String prefix) { - return new IndexConventionImpl(prefix, "MD5"); + return new IndexConventionImpl( + IndexConventionImpl.IndexConventionConfig.builder() + .prefix(prefix) + .hashIdAlgo("MD5") + .build()); } @Bean(name = "longTailIndexConvention") protected IndexConvention longTailIndexConvention(@Qualifier("longTailPrefix") String prefix) { - return new IndexConventionImpl(prefix, "MD5"); + return new IndexConventionImpl( + IndexConventionImpl.IndexConventionConfig.builder() + .prefix(prefix) + .hashIdAlgo("MD5") + .build()); } @Bean(name = "sampleDataFixtureName") diff --git a/metadata-io/src/test/java/io/datahubproject/test/fixtures/search/SearchLineageFixtureConfiguration.java b/metadata-io/src/test/java/io/datahubproject/test/fixtures/search/SearchLineageFixtureConfiguration.java index 33e04af83c0a3a..71ccaa1d325010 100644 --- a/metadata-io/src/test/java/io/datahubproject/test/fixtures/search/SearchLineageFixtureConfiguration.java +++ b/metadata-io/src/test/java/io/datahubproject/test/fixtures/search/SearchLineageFixtureConfiguration.java @@ -5,8 +5,12 @@ import com.linkedin.entity.client.EntityClient; import com.linkedin.metadata.client.JavaEntityClient; +import com.linkedin.metadata.config.DataHubAppConfiguration; +import com.linkedin.metadata.config.MetadataChangeProposalConfig; import com.linkedin.metadata.config.PreProcessHooks; +import com.linkedin.metadata.config.cache.CacheConfiguration; import com.linkedin.metadata.config.cache.EntityDocCountCacheConfiguration; +import com.linkedin.metadata.config.cache.SearchCacheConfiguration; import com.linkedin.metadata.config.cache.SearchLineageCacheConfiguration; import com.linkedin.metadata.config.search.ElasticSearchConfiguration; import com.linkedin.metadata.config.search.SearchConfiguration; @@ -71,7 +75,11 @@ protected String indexPrefix() { @Bean(name = "searchLineageIndexConvention") protected IndexConvention indexConvention(@Qualifier("searchLineagePrefix") String prefix) { - return new IndexConventionImpl(prefix, "MD5"); + return new IndexConventionImpl( + IndexConventionImpl.IndexConventionConfig.builder() + .prefix(prefix) + .hashIdAlgo("MD5") + .build()); } @Bean(name = "searchLineageFixtureName") @@ -79,11 +87,21 @@ protected String fixtureName() { return "search_lineage"; } - @Bean(name = "lineageCacheConfiguration") - protected SearchLineageCacheConfiguration searchLineageCacheConfiguration() { - SearchLineageCacheConfiguration conf = new SearchLineageCacheConfiguration(); - conf.setLightningThreshold(300); - conf.setTtlSeconds(30); + @Bean(name = "lineageAppConfig") + protected DataHubAppConfiguration searchLineageAppConfiguration() { + DataHubAppConfiguration conf = new DataHubAppConfiguration(); + conf.setCache(new CacheConfiguration()); + conf.getCache().setSearch(new SearchCacheConfiguration()); + conf.getCache().getSearch().setLineage(new SearchLineageCacheConfiguration()); + conf.getCache().getSearch().getLineage().setLightningThreshold(300); + conf.getCache().getSearch().getLineage().setTtlSeconds(30); + conf.setMetadataChangeProposal(new MetadataChangeProposalConfig()); + conf.getMetadataChangeProposal() + .setSideEffects(new MetadataChangeProposalConfig.SideEffectsConfig()); + conf.getMetadataChangeProposal() + .getSideEffects() + .setSchemaField(new MetadataChangeProposalConfig.SideEffectConfig()); + conf.getMetadataChangeProposal().getSideEffects().getSchemaField().setEnabled(false); return conf; } @@ -186,7 +204,7 @@ protected LineageSearchService lineageSearchService( @Qualifier("searchLineageGraphService") ElasticSearchGraphService graphService, @Qualifier("searchLineagePrefix") String prefix, @Qualifier("searchLineageFixtureName") String fixtureName, - @Qualifier("lineageCacheConfiguration") SearchLineageCacheConfiguration cacheConfiguration) + @Qualifier("lineageAppConfig") DataHubAppConfiguration appConfig) throws IOException { // Load fixture data (after graphService mappings applied) @@ -198,7 +216,7 @@ protected LineageSearchService lineageSearchService( .build() .read(); - return new LineageSearchService(searchService, graphService, null, false, cacheConfiguration); + return new LineageSearchService(searchService, graphService, null, false, appConfig); } @Bean(name = "searchLineageSearchService") diff --git a/metadata-io/src/test/java/io/datahubproject/test/search/SearchTestUtils.java b/metadata-io/src/test/java/io/datahubproject/test/search/SearchTestUtils.java index 24df2afb3b7819..78e274063b6c73 100644 --- a/metadata-io/src/test/java/io/datahubproject/test/search/SearchTestUtils.java +++ b/metadata-io/src/test/java/io/datahubproject/test/search/SearchTestUtils.java @@ -15,6 +15,7 @@ import com.linkedin.datahub.graphql.types.SearchableEntityType; import com.linkedin.datahub.graphql.types.entitytype.EntityTypeMapper; import com.linkedin.metadata.aspect.AspectRetriever; +import com.linkedin.metadata.config.DataHubAppConfiguration; import com.linkedin.metadata.config.search.GraphQueryConfiguration; import com.linkedin.metadata.graph.LineageDirection; import com.linkedin.metadata.query.filter.Filter; @@ -223,6 +224,11 @@ public Authorizer getAuthorizer() { public OperationContext getOperationContext() { return opContext; } + + @Override + public DataHubAppConfiguration getDataHubAppConfig() { + return new DataHubAppConfiguration(); + } }); } diff --git a/metadata-jobs/mae-consumer/src/main/java/com/linkedin/metadata/kafka/hook/event/EntityChangeEventGeneratorHook.java b/metadata-jobs/mae-consumer/src/main/java/com/linkedin/metadata/kafka/hook/event/EntityChangeEventGeneratorHook.java index 59d068a46d8c6f..de570cc91b2fe7 100644 --- a/metadata-jobs/mae-consumer/src/main/java/com/linkedin/metadata/kafka/hook/event/EntityChangeEventGeneratorHook.java +++ b/metadata-jobs/mae-consumer/src/main/java/com/linkedin/metadata/kafka/hook/event/EntityChangeEventGeneratorHook.java @@ -1,5 +1,7 @@ package com.linkedin.metadata.kafka.hook.event; +import static com.linkedin.metadata.Constants.SCHEMA_FIELD_ENTITY_NAME; + import com.google.common.annotations.VisibleForTesting; import com.google.common.collect.ImmutableSet; import com.linkedin.common.AuditStamp; @@ -14,6 +16,7 @@ import com.linkedin.metadata.models.AspectSpec; import com.linkedin.metadata.timeline.data.ChangeEvent; import com.linkedin.metadata.timeline.eventgenerator.Aspect; +import com.linkedin.metadata.timeline.eventgenerator.ChangeEventGeneratorUtils; import com.linkedin.metadata.timeline.eventgenerator.EntityChangeEventGenerator; import com.linkedin.metadata.timeline.eventgenerator.EntityChangeEventGeneratorRegistry; import com.linkedin.metadata.utils.GenericRecordUtils; @@ -80,9 +83,11 @@ public class EntityChangeEventGeneratorHook implements MetadataChangeLogHook { private static final Set SUPPORTED_OPERATIONS = ImmutableSet.of("CREATE", "UPSERT", "DELETE"); + private static final Set ENTITY_EXCLUSIONS = ImmutableSet.of(SCHEMA_FIELD_ENTITY_NAME); + private final EntityChangeEventGeneratorRegistry entityChangeEventGeneratorRegistry; private final OperationContext systemOperationContext; - private final SystemEntityClient entityClient; + private final SystemEntityClient systemEntityClient; private final Boolean isEnabled; @Getter private final String consumerGroupSuffix; @@ -97,7 +102,7 @@ public EntityChangeEventGeneratorHook( this.systemOperationContext = systemOperationContext; this.entityChangeEventGeneratorRegistry = Objects.requireNonNull(entityChangeEventGeneratorRegistry); - this.entityClient = Objects.requireNonNull(entityClient); + this.systemEntityClient = Objects.requireNonNull(entityClient); this.isEnabled = isEnabled; this.consumerGroupSuffix = consumerGroupSuffix; } @@ -148,7 +153,8 @@ public void invoke(@Nonnull final MetadataChangeLog logEvent) throws Exception { : null; final List changeEvents = - generateChangeEvents( + ChangeEventGeneratorUtils.generateChangeEvents( + entityChangeEventGeneratorRegistry, logEvent.getEntityUrn(), logEvent.getEntityType(), logEvent.getAspectName(), @@ -195,12 +201,13 @@ private List generateChangeEvents( private boolean isEligibleForProcessing(final MetadataChangeLog log) { return SUPPORTED_OPERATIONS.contains(log.getChangeType().toString()) - && SUPPORTED_ASPECT_NAMES.contains(log.getAspectName()); + && SUPPORTED_ASPECT_NAMES.contains(log.getAspectName()) + && !ENTITY_EXCLUSIONS.contains(log.getEntityType()); } private void emitPlatformEvent( @Nonnull final PlatformEvent event, @Nonnull final String partitioningKey) throws Exception { - entityClient.producePlatformEvent( + systemEntityClient.producePlatformEvent( systemOperationContext, Constants.CHANGE_EVENT_PLATFORM_EVENT_NAME, partitioningKey, event); } diff --git a/metadata-jobs/mae-consumer/src/test/java/com/linkedin/metadata/kafka/hook/UpdateIndicesHookTest.java b/metadata-jobs/mae-consumer/src/test/java/com/linkedin/metadata/kafka/hook/UpdateIndicesHookTest.java index 4cd59992eb2f00..9f6734852bd252 100644 --- a/metadata-jobs/mae-consumer/src/test/java/com/linkedin/metadata/kafka/hook/UpdateIndicesHookTest.java +++ b/metadata-jobs/mae-consumer/src/test/java/com/linkedin/metadata/kafka/hook/UpdateIndicesHookTest.java @@ -4,6 +4,7 @@ import static com.linkedin.metadata.kafka.hook.MCLProcessingTestDataGenerator.*; import static com.linkedin.metadata.search.utils.QueryUtils.newRelationshipFilter; import static org.mockito.ArgumentMatchers.any; +import static org.mockito.Mockito.when; import com.linkedin.common.AuditStamp; import com.linkedin.common.InputField; @@ -47,6 +48,7 @@ import com.linkedin.metadata.systemmetadata.SystemMetadataService; import com.linkedin.metadata.timeseries.TimeseriesAspectService; import com.linkedin.metadata.utils.GenericRecordUtils; +import com.linkedin.metadata.utils.elasticsearch.IndexConventionImpl; import com.linkedin.mxe.MetadataChangeLog; import com.linkedin.mxe.SystemMetadata; import com.linkedin.schema.NumberType; @@ -113,11 +115,12 @@ public void setupTest() { mockConfigurationProvider = Mockito.mock(ConfigurationProvider.class); mockEntityIndexBuilders = Mockito.mock(EntityIndexBuilders.class); + when(mockEntityIndexBuilders.getIndexConvention()).thenReturn(IndexConventionImpl.noPrefix("")); + ElasticSearchConfiguration elasticSearchConfiguration = new ElasticSearchConfiguration(); SystemUpdateConfiguration systemUpdateConfiguration = new SystemUpdateConfiguration(); systemUpdateConfiguration.setWaitForSystemUpdate(false); - Mockito.when(mockConfigurationProvider.getElasticSearch()) - .thenReturn(elasticSearchConfiguration); + when(mockConfigurationProvider.getElasticSearch()).thenReturn(elasticSearchConfiguration); updateIndicesService = new UpdateIndicesService( mockGraphService, @@ -485,32 +488,27 @@ private EntityRegistry createMockEntityRegistry() { AspectSpec aspectSpec = createMockAspectSpec(InputFields.class, InputFields.dataSchema()); AspectSpec upstreamLineageAspectSpec = createMockAspectSpec(UpstreamLineage.class, UpstreamLineage.dataSchema()); - Mockito.when(mockEntityRegistry.getEntitySpec(Constants.CHART_ENTITY_NAME)) - .thenReturn(entitySpec); - Mockito.when(mockEntityRegistry.getEntitySpec(Constants.DATASET_ENTITY_NAME)) - .thenReturn(entitySpec); - Mockito.when(mockEntityRegistry.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)).thenReturn(entitySpec); - Mockito.when(mockEntityRegistry.getEntitySpec(DATA_PLATFORM_ENTITY_NAME)) - .thenReturn(entitySpec); - Mockito.when(entitySpec.getAspectSpec(Constants.INPUT_FIELDS_ASPECT_NAME)) - .thenReturn(aspectSpec); - Mockito.when(entitySpec.getAspectSpec(Constants.UPSTREAM_LINEAGE_ASPECT_NAME)) + when(mockEntityRegistry.getEntitySpec(Constants.CHART_ENTITY_NAME)).thenReturn(entitySpec); + when(mockEntityRegistry.getEntitySpec(Constants.DATASET_ENTITY_NAME)).thenReturn(entitySpec); + when(mockEntityRegistry.getEntitySpec(SCHEMA_FIELD_ENTITY_NAME)).thenReturn(entitySpec); + when(mockEntityRegistry.getEntitySpec(DATA_PLATFORM_ENTITY_NAME)).thenReturn(entitySpec); + when(entitySpec.getAspectSpec(Constants.INPUT_FIELDS_ASPECT_NAME)).thenReturn(aspectSpec); + when(entitySpec.getAspectSpec(Constants.UPSTREAM_LINEAGE_ASPECT_NAME)) .thenReturn(upstreamLineageAspectSpec); - Mockito.when(aspectSpec.isTimeseries()).thenReturn(false); - Mockito.when(aspectSpec.getName()).thenReturn(Constants.INPUT_FIELDS_ASPECT_NAME); - Mockito.when(upstreamLineageAspectSpec.isTimeseries()).thenReturn(false); - Mockito.when(upstreamLineageAspectSpec.getName()) - .thenReturn(Constants.UPSTREAM_LINEAGE_ASPECT_NAME); + when(aspectSpec.isTimeseries()).thenReturn(false); + when(aspectSpec.getName()).thenReturn(Constants.INPUT_FIELDS_ASPECT_NAME); + when(upstreamLineageAspectSpec.isTimeseries()).thenReturn(false); + when(upstreamLineageAspectSpec.getName()).thenReturn(Constants.UPSTREAM_LINEAGE_ASPECT_NAME); AspectSpec chartKeyAspectSpec = createMockAspectSpec(ChartKey.class, ChartKey.dataSchema()); - Mockito.when(entitySpec.getKeyAspectSpec()).thenReturn(chartKeyAspectSpec); + when(entitySpec.getKeyAspectSpec()).thenReturn(chartKeyAspectSpec); return mockEntityRegistry; } private AspectSpec createMockAspectSpec( Class clazz, RecordDataSchema schema) { AspectSpec mockSpec = Mockito.mock(AspectSpec.class); - Mockito.when(mockSpec.getDataTemplateClass()).thenReturn((Class) clazz); - Mockito.when(mockSpec.getPegasusSchema()).thenReturn(schema); + when(mockSpec.getDataTemplateClass()).thenReturn((Class) clazz); + when(mockSpec.getPegasusSchema()).thenReturn(schema); return mockSpec; } diff --git a/metadata-models/src/main/pegasus/com/linkedin/dataproduct/DataProductAssociation.pdl b/metadata-models/src/main/pegasus/com/linkedin/dataproduct/DataProductAssociation.pdl index 93bd9a4e0e5610..bb43695427c636 100644 --- a/metadata-models/src/main/pegasus/com/linkedin/dataproduct/DataProductAssociation.pdl +++ b/metadata-models/src/main/pegasus/com/linkedin/dataproduct/DataProductAssociation.pdl @@ -7,4 +7,9 @@ import com.linkedin.common.Edge **/ record DataProductAssociation includes Edge { + /** + * If set to true, this asset is an output port of the Data Product. + */ + outputPort: boolean = false + } \ No newline at end of file diff --git a/metadata-models/src/main/pegasus/com/linkedin/metadata/search/SearchEntity.pdl b/metadata-models/src/main/pegasus/com/linkedin/metadata/search/SearchEntity.pdl index df457c1ba26f99..046c076dd151df 100644 --- a/metadata-models/src/main/pegasus/com/linkedin/metadata/search/SearchEntity.pdl +++ b/metadata-models/src/main/pegasus/com/linkedin/metadata/search/SearchEntity.pdl @@ -35,4 +35,9 @@ record SearchEntity { * If the key aspect is present, assume ALL aspects should be restricted including the entity's Urn. */ restrictedAspects: optional array[string] + + /** + * Extra fields from the search document based on what is requested in the search request + */ + extraFields: optional map[string, string] } \ No newline at end of file diff --git a/metadata-models/src/main/pegasus/com/linkedin/post/PostInfo.pdl b/metadata-models/src/main/pegasus/com/linkedin/post/PostInfo.pdl index 7eb080653e9c33..70ff38f3b7633c 100644 --- a/metadata-models/src/main/pegasus/com/linkedin/post/PostInfo.pdl +++ b/metadata-models/src/main/pegasus/com/linkedin/post/PostInfo.pdl @@ -1,5 +1,8 @@ namespace com.linkedin.post +import com.linkedin.common.Urn +import com.linkedin.common.AuditStamp + /** * Information about a DataHub Post. */ @@ -32,4 +35,24 @@ record PostInfo { "fieldType": "COUNT" } lastModified: long + + /** + * The audit stamp at which the request was last updated + */ + @Searchable = { + "/time": { + "fieldName": "created", + "fieldType": "COUNT" + } + } + auditStamp: optional AuditStamp + + /** + * Optional URN that the post is associated with. + */ + @Relationship = { + "name": "PostTarget", + "entityTypes": [ "dataset", "schemaField", "chart", "dashboard", "dataFlow", "dataJob", "dataProduct" ] + } + target: optional Urn } \ No newline at end of file diff --git a/metadata-models/src/main/pegasus/com/linkedin/schemafield/schemaFieldAliases.pdl b/metadata-models/src/main/pegasus/com/linkedin/schemafield/schemaFieldAliases.pdl new file mode 100644 index 00000000000000..d735ef6305d549 --- /dev/null +++ b/metadata-models/src/main/pegasus/com/linkedin/schemafield/schemaFieldAliases.pdl @@ -0,0 +1,22 @@ +namespace com.linkedin.schemafield + +import com.linkedin.common.Urn + +@Aspect = { + "name": "schemaFieldAliases" +} + +record SchemaFieldAliases { + + /** + * Used to store aliases + */ + @Searchable = { + "/*": { + "fieldName": "schemaFieldAliases", + "fieldType": "URN", + "queryByDefault": false, + } + } + aliases: optional array[Urn] +} \ No newline at end of file diff --git a/metadata-models/src/main/pegasus/com/linkedin/schemafield/schemafieldInfo.pdl b/metadata-models/src/main/pegasus/com/linkedin/schemafield/schemafieldInfo.pdl index 086d9df34deadd..b29ca928765986 100644 --- a/metadata-models/src/main/pegasus/com/linkedin/schemafield/schemafieldInfo.pdl +++ b/metadata-models/src/main/pegasus/com/linkedin/schemafield/schemafieldInfo.pdl @@ -1,5 +1,7 @@ namespace com.linkedin.schemafield +import com.linkedin.common.Urn + @Aspect = { "name": "schemafieldInfo" } @@ -8,6 +10,17 @@ record SchemaFieldInfo { @Searchable = { "fieldType": "KEYWORD", "fieldNameAliases": [ "_entityName" ] - } - name: optional string + } + name: optional string + + /** + * Used to store field path variations for the schemaField urn. + */ + @Searchable = { + "/*": { + "fieldType": "URN", + "queryByDefault": true, + } + } + schemaFieldAliases: optional array[Urn] } \ No newline at end of file diff --git a/metadata-models/src/main/pegasus/com/linkedin/upgrade/DataHubUpgradeResult.pdl b/metadata-models/src/main/pegasus/com/linkedin/upgrade/DataHubUpgradeResult.pdl index fc5becba979411..c9c08270c29b02 100644 --- a/metadata-models/src/main/pegasus/com/linkedin/upgrade/DataHubUpgradeResult.pdl +++ b/metadata-models/src/main/pegasus/com/linkedin/upgrade/DataHubUpgradeResult.pdl @@ -8,6 +8,11 @@ namespace com.linkedin.upgrade } record DataHubUpgradeResult { + /** + * Upgrade state UpgradeResult.Result + */ + state: optional DataHubUpgradeState = "SUCCEEDED" + /** * Timestamp when we started this DataHubUpgrade */ diff --git a/metadata-models/src/main/pegasus/com/linkedin/upgrade/DataHubUpgradeState.pdl b/metadata-models/src/main/pegasus/com/linkedin/upgrade/DataHubUpgradeState.pdl new file mode 100644 index 00000000000000..d620f29f3d882e --- /dev/null +++ b/metadata-models/src/main/pegasus/com/linkedin/upgrade/DataHubUpgradeState.pdl @@ -0,0 +1,23 @@ +namespace com.linkedin.upgrade + +enum DataHubUpgradeState { + /** + * Upgrade in progress. + */ + IN_PROGRESS + + /** + * Upgrade was successful. + */ + SUCCEEDED + + /** + * Upgrade with an error state, however the upgrade should be re-run. + */ + FAILED + + /** + * Upgrade with an error state and should not be re-run. + */ + ABORTED +} \ No newline at end of file diff --git a/metadata-models/src/main/resources/entity-registry.yml b/metadata-models/src/main/resources/entity-registry.yml index f8520990a09841..7beb08a6b1032f 100644 --- a/metadata-models/src/main/resources/entity-registry.yml +++ b/metadata-models/src/main/resources/entity-registry.yml @@ -475,6 +475,8 @@ entities: - structuredProperties - forms - businessAttributes + - status + - schemaFieldAliases - documentation - testResults - name: globalSettings @@ -672,6 +674,12 @@ plugins: aspectName: propertyDefinition - entityName: structuredProperty aspectName: structuredPropertyKey + - className: 'com.linkedin.metadata.aspect.plugins.hooks.MCPSideEffect' + enabled: true + spring: + enabled: true + packageScan: + - com.linkedin.gms.factory.plugins mutationHooks: - className: 'com.linkedin.metadata.structuredproperties.hooks.StructuredPropertiesSoftDelete' packageScan: diff --git a/metadata-operation-context/src/test/java/io/datahubproject/metadata/context/SearchContextTest.java b/metadata-operation-context/src/test/java/io/datahubproject/metadata/context/SearchContextTest.java index 2e0585cc82a4fd..ba955af9a113da 100644 --- a/metadata-operation-context/src/test/java/io/datahubproject/metadata/context/SearchContextTest.java +++ b/metadata-operation-context/src/test/java/io/datahubproject/metadata/context/SearchContextTest.java @@ -53,7 +53,12 @@ public void searchContextId() { assertNotEquals( testNoFlags.getCacheKeyComponent(), SearchContext.builder() - .indexConvention(new IndexConventionImpl("Some Prefix", "MD5")) + .indexConvention( + new IndexConventionImpl( + IndexConventionImpl.IndexConventionConfig.builder() + .prefix("Some Prefix") + .hashIdAlgo("MD5") + .build())) .searchFlags(null) .build() .getCacheKeyComponent(), diff --git a/metadata-service/auth-impl/src/main/java/com/datahub/authentication/post/PostService.java b/metadata-service/auth-impl/src/main/java/com/datahub/authentication/post/PostService.java index f5cb5edb608e06..63e5fcb2c4bbdc 100644 --- a/metadata-service/auth-impl/src/main/java/com/datahub/authentication/post/PostService.java +++ b/metadata-service/auth-impl/src/main/java/com/datahub/authentication/post/PostService.java @@ -2,6 +2,7 @@ import static com.linkedin.metadata.Constants.*; import static com.linkedin.metadata.entity.AspectUtils.*; +import static com.linkedin.metadata.utils.SystemMetadataUtils.createDefaultSystemMetadata; import com.linkedin.common.Media; import com.linkedin.common.MediaType; @@ -63,10 +64,11 @@ public PostContent mapPostContent( } public boolean createPost( - @Nonnull OperationContext opCcontext, + @Nonnull OperationContext opContext, @Nonnull String postType, - @Nonnull PostContent postContent) - throws RemoteInvocationException { + @Nonnull PostContent postContent, + @Nullable String targetUrn) + throws RemoteInvocationException, URISyntaxException { final String uuid = UUID.randomUUID().toString(); final PostKey postKey = new PostKey().setId(uuid); final long currentTimeMillis = Instant.now().toEpochMilli(); @@ -75,11 +77,28 @@ public boolean createPost( .setType(PostType.valueOf(postType)) .setContent(postContent) .setCreated(currentTimeMillis) + .setAuditStamp( + new com.linkedin.common.AuditStamp() + .setTime(currentTimeMillis) + .setActor( + Urn.createFromString( + opContext.getSessionAuthentication().getActor().toUrnStr()))) .setLastModified(currentTimeMillis); + if (targetUrn != null) { + try { + postInfo.setTarget(Urn.createFromString(targetUrn)); + } catch (URISyntaxException e) { + throw new RuntimeException(e); + } + } + final MetadataChangeProposal proposal = buildMetadataChangeProposal(POST_ENTITY_NAME, postKey, POST_INFO_ASPECT_NAME, postInfo); - _entityClient.ingestProposal(opCcontext, proposal); + + proposal.setSystemMetadata(createDefaultSystemMetadata()); + + _entityClient.ingestProposal(opContext, proposal); return true; } diff --git a/metadata-service/auth-impl/src/test/java/com/datahub/authentication/post/PostServiceTest.java b/metadata-service/auth-impl/src/test/java/com/datahub/authentication/post/PostServiceTest.java index a4f7ad6cd6780e..1028e28ed1624f 100644 --- a/metadata-service/auth-impl/src/test/java/com/datahub/authentication/post/PostServiceTest.java +++ b/metadata-service/auth-impl/src/test/java/com/datahub/authentication/post/PostServiceTest.java @@ -18,11 +18,13 @@ import com.linkedin.r2.RemoteInvocationException; import io.datahubproject.metadata.context.OperationContext; import io.datahubproject.test.metadata.context.TestOperationContexts; +import java.net.URISyntaxException; import org.testng.annotations.BeforeMethod; import org.testng.annotations.Test; public class PostServiceTest { private static final Urn POST_URN = UrnUtils.getUrn("urn:li:post:123"); + private static final Urn ENTITY_URN = UrnUtils.getUrn("urn:li:domain:123"); private static final MediaType POST_MEDIA_TYPE = MediaType.IMAGE; private static final String POST_MEDIA_LOCATION = "https://datahubproject.io/img/datahub-logo-color-light-horizontal.svg"; @@ -69,8 +71,8 @@ public void testMapPostContent() { } @Test - public void testCreatePost() throws RemoteInvocationException { - _postService.createPost(opContext, POST_TYPE.toString(), POST_CONTENT); + public void testCreatePost() throws RemoteInvocationException, URISyntaxException { + _postService.createPost(opContext, POST_TYPE.toString(), POST_CONTENT, ENTITY_URN.toString()); verify(_entityClient, times(1)).ingestProposal(any(OperationContext.class), any()); } diff --git a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/featureflags/FeatureFlags.java b/metadata-service/configuration/src/main/java/com/linkedin/datahub/graphql/featureflags/FeatureFlags.java similarity index 100% rename from datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/featureflags/FeatureFlags.java rename to metadata-service/configuration/src/main/java/com/linkedin/datahub/graphql/featureflags/FeatureFlags.java diff --git a/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/DataHubAppConfiguration.java b/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/DataHubAppConfiguration.java new file mode 100644 index 00000000000000..28cc9304bf913f --- /dev/null +++ b/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/DataHubAppConfiguration.java @@ -0,0 +1,57 @@ +package com.linkedin.metadata.config; + +import com.linkedin.datahub.graphql.featureflags.FeatureFlags; +import com.linkedin.metadata.config.cache.CacheConfiguration; +import com.linkedin.metadata.config.kafka.KafkaConfiguration; +import com.linkedin.metadata.config.search.ElasticSearchConfiguration; +import com.linkedin.metadata.config.telemetry.TelemetryConfiguration; +import lombok.Data; + +@Data +public class DataHubAppConfiguration { + + /** Ingestion related configs */ + private IngestionConfiguration ingestion; + + /** Telemetry related configs */ + private TelemetryConfiguration telemetry; + + /** Viz related configs */ + private VisualConfiguration visualConfig; + + /** Tests related configs */ + private TestsConfiguration metadataTests; + + /** DataHub top-level server configurations */ + private DataHubConfiguration datahub; + + /** Views feature related configs */ + private ViewsConfiguration views; + + /** Feature flags indicating what is turned on vs turned off */ + private FeatureFlags featureFlags; + + /** Kafka related configs. */ + private KafkaConfiguration kafka; + + /** ElasticSearch configurations */ + private ElasticSearchConfiguration elasticSearch; + + /** System Update configurations */ + private SystemUpdateConfiguration systemUpdate; + + /** The base URL where DataHub is hosted. */ + private String baseUrl; + + /** Configuration for caching */ + private CacheConfiguration cache; + + /** Ebean related configuration */ + private EbeanConfiguration ebean; + + /** GraphQL Configurations */ + private GraphQLConfiguration graphQL; + + /** MCP throttling configuration */ + private MetadataChangeProposalConfig metadataChangeProposal; +} diff --git a/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/MetadataChangeProposalConfig.java b/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/MetadataChangeProposalConfig.java index 3d3808bc5feb45..f988758beee363 100644 --- a/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/MetadataChangeProposalConfig.java +++ b/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/MetadataChangeProposalConfig.java @@ -8,6 +8,7 @@ public class MetadataChangeProposalConfig { ThrottlesConfig throttle; + SideEffectsConfig sideEffects; @Data @Accessors(chain = true) @@ -27,4 +28,16 @@ public static class ThrottleConfig { Integer multiplier; Integer maxIntervalMs; } + + @Data + @Accessors(chain = true) + public static class SideEffectsConfig { + SideEffectConfig schemaField; + } + + @Data + @Accessors(chain = true) + public static class SideEffectConfig { + boolean enabled; + } } diff --git a/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/search/DocIdsConfiguration.java b/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/search/DocIdsConfiguration.java new file mode 100644 index 00000000000000..56bcbc8d0c4fd5 --- /dev/null +++ b/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/search/DocIdsConfiguration.java @@ -0,0 +1,8 @@ +package com.linkedin.metadata.config.search; + +import lombok.Data; + +@Data +public class DocIdsConfiguration { + private EntityDocIdConfiguration schemaField; +} diff --git a/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/search/ElasticSearchConfiguration.java b/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/search/ElasticSearchConfiguration.java index 7d68e18940401e..9426c83f17b708 100644 --- a/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/search/ElasticSearchConfiguration.java +++ b/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/search/ElasticSearchConfiguration.java @@ -9,4 +9,5 @@ public class ElasticSearchConfiguration { public String implementation; private SearchConfiguration search; private String idHashAlgo; + private IndexConfiguration index; } diff --git a/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/search/EntityDocIdConfiguration.java b/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/search/EntityDocIdConfiguration.java new file mode 100644 index 00000000000000..5e580fe30ee32c --- /dev/null +++ b/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/search/EntityDocIdConfiguration.java @@ -0,0 +1,8 @@ +package com.linkedin.metadata.config.search; + +import lombok.Data; + +@Data +public class EntityDocIdConfiguration { + private boolean hashIdEnabled; +} diff --git a/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/search/IndexConfiguration.java b/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/search/IndexConfiguration.java new file mode 100644 index 00000000000000..b54cc89726858c --- /dev/null +++ b/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/search/IndexConfiguration.java @@ -0,0 +1,9 @@ +package com.linkedin.metadata.config.search; + +import lombok.Data; + +@Data +public class IndexConfiguration { + private String prefix; + private DocIdsConfiguration docIds; +} diff --git a/metadata-service/configuration/src/main/resources/application.yaml b/metadata-service/configuration/src/main/resources/application.yaml index 37399466c50b0c..8a667ca056a35c 100644 --- a/metadata-service/configuration/src/main/resources/application.yaml +++ b/metadata-service/configuration/src/main/resources/application.yaml @@ -209,6 +209,9 @@ elasticsearch: enableSettingsReindex: ${ELASTICSEARCH_INDEX_BUILDER_SETTINGS_REINDEX:false} settingsOverrides: ${ELASTICSEARCH_INDEX_BUILDER_SETTINGS_OVERRIDES:#{null}} entitySettingsOverrides: ${ELASTICSEARCH_INDEX_BUILDER_ENTITY_SETTINGS_OVERRIDES:#{null}} + docIds: + schemaField: + hashIdEnabled: ${ELASTICSEARCH_INDEX_DOC_IDS_SCHEMA_FIELD_HASH_ID_ENABLED:false} buildIndices: allowDocCountMismatch: ${ELASTICSEARCH_BUILD_INDICES_ALLOW_DOC_COUNT_MISMATCH:false} # when cloneIndices is also enabled cloneIndices: ${ELASTICSEARCH_BUILD_INDICES_CLONE_INDICES:true} @@ -357,6 +360,16 @@ systemUpdate: batchSize: ${BOOTSTRAP_SYSTEM_UPDATE_OWNERSHIP_TYPES_BATCH_SIZE:1000} reprocess: enabled: ${BOOTSTRAP_SYSTEM_UPDATE_OWNERSHIP_TYPES_REPROCESS:false} + schemaFieldsFromSchemaMetadata: + enabled: ${SYSTEM_UPDATE_SCHEMA_FIELDS_FROM_SCHEMA_METADATA_ENABLED:false} + batchSize: ${SYSTEM_UPDATE_SCHEMA_FIELDS_FROM_SCHEMA_METADATA_BATCH_SIZE:500} + delayMs: ${SYSTEM_UPDATE_SCHEMA_FIELDS_FROM_SCHEMA_METADATA_DELAY_MS:1000} + limit: ${SYSTEM_UPDATE_SCHEMA_FIELDS_FROM_SCHEMA_METADATA_LIMIT:0} + schemaFieldsDocIds: + enabled: ${SYSTEM_UPDATE_SCHEMA_FIELDS_DOC_IDS_ENABLED:false} + batchSize: ${SYSTEM_UPDATE_SCHEMA_FIELDS_DOC_IDS_BATCH_SIZE:500} + delayMs: ${SYSTEM_UPDATE_SCHEMA_FIELDS_DOC_IDS_DELAY_MS:5000} + limit: ${SYSTEM_UPDATE_SCHEMA_FIELDS_DOC_IDS_LIMIT:0} structuredProperties: enabled: ${ENABLE_STRUCTURED_PROPERTIES_HOOK:true} # applies structured properties mappings @@ -487,6 +500,9 @@ businessAttribute: metadataChangeProposal: validation: ignoreUnknown: ${MCP_VALIDATION_IGNORE_UNKNOWN:true} + sideEffects: + schemaField: + enabled: ${MCP_SIDE_EFFECTS_SCHEMA_FIELD_ENABLED:false} throttle: updateIntervalMs: ${MCP_THROTTLE_UPDATE_INTERVAL_MS:60000} diff --git a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/common/IndexConventionFactory.java b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/common/IndexConventionFactory.java index 2288c8d4ecd50d..859c9cfcd58bad 100644 --- a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/common/IndexConventionFactory.java +++ b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/common/IndexConventionFactory.java @@ -1,8 +1,9 @@ package com.linkedin.gms.factory.common; +import com.linkedin.gms.factory.config.ConfigurationProvider; +import com.linkedin.metadata.config.search.ElasticSearchConfiguration; import com.linkedin.metadata.utils.elasticsearch.IndexConvention; import com.linkedin.metadata.utils.elasticsearch.IndexConventionImpl; -import org.springframework.beans.factory.annotation.Value; import org.springframework.context.annotation.Bean; import org.springframework.context.annotation.Configuration; @@ -15,12 +16,20 @@ public class IndexConventionFactory { public static final String INDEX_CONVENTION_BEAN = "searchIndexConvention"; - @Value("${elasticsearch.index.prefix:}") - private String indexPrefix; - @Bean(name = INDEX_CONVENTION_BEAN) - protected IndexConvention createInstance( - @Value("${elasticsearch.idHashAlgo}") final String isHashAlgo) { - return new IndexConventionImpl(indexPrefix, isHashAlgo); + protected IndexConvention createInstance(final ConfigurationProvider configurationProvider) { + ElasticSearchConfiguration elasticSearchConfiguration = + configurationProvider.getElasticSearch(); + return new IndexConventionImpl( + IndexConventionImpl.IndexConventionConfig.builder() + .prefix(elasticSearchConfiguration.getIndex().getPrefix()) + .hashIdAlgo(elasticSearchConfiguration.getIdHashAlgo()) + .schemaFieldDocIdHashEnabled( + elasticSearchConfiguration + .getIndex() + .getDocIds() + .getSchemaField() + .isHashIdEnabled()) + .build()); } } diff --git a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/config/ConfigurationProvider.java b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/config/ConfigurationProvider.java index 08adbd54730a74..f57829baba6baa 100644 --- a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/config/ConfigurationProvider.java +++ b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/config/ConfigurationProvider.java @@ -2,86 +2,30 @@ import com.datahub.authentication.AuthenticationConfiguration; import com.datahub.authorization.AuthorizationConfiguration; -import com.linkedin.datahub.graphql.featureflags.FeatureFlags; -import com.linkedin.metadata.config.DataHubConfiguration; -import com.linkedin.metadata.config.EbeanConfiguration; -import com.linkedin.metadata.config.GraphQLConfiguration; -import com.linkedin.metadata.config.IngestionConfiguration; -import com.linkedin.metadata.config.MetadataChangeProposalConfig; -import com.linkedin.metadata.config.SystemUpdateConfiguration; -import com.linkedin.metadata.config.TestsConfiguration; -import com.linkedin.metadata.config.ViewsConfiguration; -import com.linkedin.metadata.config.VisualConfiguration; -import com.linkedin.metadata.config.cache.CacheConfiguration; -import com.linkedin.metadata.config.kafka.KafkaConfiguration; -import com.linkedin.metadata.config.search.ElasticSearchConfiguration; -import com.linkedin.metadata.config.telemetry.TelemetryConfiguration; +import com.linkedin.metadata.config.DataHubAppConfiguration; import lombok.Data; +import lombok.EqualsAndHashCode; import org.springframework.boot.autoconfigure.kafka.KafkaProperties; import org.springframework.boot.context.properties.ConfigurationProperties; import org.springframework.boot.context.properties.EnableConfigurationProperties; import org.springframework.stereotype.Component; +@EqualsAndHashCode(callSuper = true) @Component // Include extra kafka properties @EnableConfigurationProperties(KafkaProperties.class) @ConfigurationProperties @Data -public class ConfigurationProvider { +public class ConfigurationProvider extends DataHubAppConfiguration { /** Authentication related configs */ private AuthenticationConfiguration authentication; /** Authorizer related configs */ private AuthorizationConfiguration authorization; - /** Ingestion related configs */ - private IngestionConfiguration ingestion; - - /** Telemetry related configs */ - private TelemetryConfiguration telemetry; - - /** Viz related configs */ - private VisualConfiguration visualConfig; - - /** Tests related configs */ - private TestsConfiguration metadataTests; - - /** DataHub top-level server configurations */ - private DataHubConfiguration datahub; - - /** Views feature related configs */ - private ViewsConfiguration views; - - /** Feature flags indicating what is turned on vs turned off */ - private FeatureFlags featureFlags; - - /** Kafka related configs. */ - private KafkaConfiguration kafka; - - /** ElasticSearch configurations */ - private ElasticSearchConfiguration elasticSearch; - - /** System Update configurations */ - private SystemUpdateConfiguration systemUpdate; - - /** The base URL where DataHub is hosted. */ - private String baseUrl; - - /** Configuration for caching */ - private CacheConfiguration cache; - /** Configuration for the health check server */ private HealthCheckConfiguration healthCheck; /** Structured properties related configurations */ private StructuredPropertiesConfiguration structuredProperties; - - /** Ebean related configuration */ - private EbeanConfiguration ebean; - - /** GraphQL Configurations */ - private GraphQLConfiguration graphQL; - - /** MCP throttling configuration */ - private MetadataChangeProposalConfig metadataChangeProposal; } diff --git a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/context/SystemOperationContextFactory.java b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/context/SystemOperationContextFactory.java index 6870d10c870016..9d92468ce649f7 100644 --- a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/context/SystemOperationContextFactory.java +++ b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/context/SystemOperationContextFactory.java @@ -17,7 +17,6 @@ import io.datahubproject.metadata.context.ServicesRegistryContext; import io.datahubproject.metadata.services.RestrictedService; import javax.annotation.Nonnull; -import org.springframework.beans.factory.annotation.Autowired; import org.springframework.beans.factory.annotation.Qualifier; import org.springframework.boot.autoconfigure.condition.ConditionalOnProperty; import org.springframework.context.annotation.Bean; @@ -26,10 +25,6 @@ @Configuration public class SystemOperationContextFactory { - @Autowired - @Qualifier("baseElasticSearchComponents") - private BaseElasticSearchComponentsFactory.BaseElasticSearchComponents components; - /** * Used inside GMS * @@ -45,7 +40,9 @@ protected OperationContext javaSystemOperationContext( @Nonnull final EntityService entityService, @Nonnull final RestrictedService restrictedService, @Nonnull final GraphRetriever graphRetriever, - @Nonnull final SearchService searchService) { + @Nonnull final SearchService searchService, + @Qualifier("baseElasticSearchComponents") + BaseElasticSearchComponentsFactory.BaseElasticSearchComponents components) { EntityServiceAspectRetriever entityServiceAspectRetriever = EntityServiceAspectRetriever.builder() @@ -91,7 +88,9 @@ protected OperationContext restliSystemOperationContext( @Nonnull final OperationContextConfig operationContextConfig, @Nonnull final RestrictedService restrictedService, @Nonnull final GraphRetriever graphRetriever, - @Nonnull final SearchService searchService) { + @Nonnull final SearchService searchService, + @Qualifier("baseElasticSearchComponents") + BaseElasticSearchComponentsFactory.BaseElasticSearchComponents components) { EntityClientAspectRetriever entityServiceAspectRetriever = EntityClientAspectRetriever.builder().entityClient(systemEntityClient).build(); diff --git a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/SystemUpdateSchemaRegistryFactory.java b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/SystemUpdateSchemaRegistryFactory.java index d02cdc0e68f529..9f2e7f60793a3e 100644 --- a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/SystemUpdateSchemaRegistryFactory.java +++ b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/SystemUpdateSchemaRegistryFactory.java @@ -27,6 +27,7 @@ public class SystemUpdateSchemaRegistryFactory { SYSTEM_UPDATE_TOPIC_KEY_PREFIX + "duhe"; public static final String MCL_VERSIONED_SCHEMA_REGISTRY_TOPIC_KEY = SYSTEM_UPDATE_TOPIC_KEY_PREFIX + "mcl-versioned"; + public static final String MCP_SCHEMA_REGISTRY_TOPIC_KEY = SYSTEM_UPDATE_TOPIC_KEY_PREFIX + "mcp"; @Value(TOPIC_NAME) private String duheTopicName; @@ -34,6 +35,9 @@ public class SystemUpdateSchemaRegistryFactory { @Value("${METADATA_CHANGE_LOG_VERSIONED_TOPIC_NAME:" + Topics.METADATA_CHANGE_LOG_VERSIONED + "}") private String mclTopicName; + @Value("${METADATA_CHANGE_PROPOSAL_TOPIC_NAME:" + Topics.METADATA_CHANGE_PROPOSAL + "}") + private String mcpTopicName; + /** Configure Kafka Producer/Consumer processes with a custom schema registry. */ @Bean("duheSchemaRegistryConfig") protected SchemaRegistryConfig duheSchemaRegistryConfig( @@ -49,15 +53,18 @@ protected SchemaRegistryConfig duheSchemaRegistryConfig( props.putAll( Map.of( DUHE_SCHEMA_REGISTRY_TOPIC_KEY, duheTopicName, - MCL_VERSIONED_SCHEMA_REGISTRY_TOPIC_KEY, mclTopicName)); + MCL_VERSIONED_SCHEMA_REGISTRY_TOPIC_KEY, mclTopicName, + MCP_SCHEMA_REGISTRY_TOPIC_KEY, mcpTopicName)); // topic ordinals props.putAll( Map.of( DUHE_SCHEMA_REGISTRY_TOPIC_KEY + SYSTEM_UPDATE_TOPIC_KEY_ID_SUFFIX, - schemaRegistryService.getSchemaIdForTopic(duheTopicName).get().toString(), + schemaRegistryService.getSchemaIdForTopic(duheTopicName).get().toString(), MCL_VERSIONED_SCHEMA_REGISTRY_TOPIC_KEY + SYSTEM_UPDATE_TOPIC_KEY_ID_SUFFIX, - schemaRegistryService.getSchemaIdForTopic(mclTopicName).get().toString())); + schemaRegistryService.getSchemaIdForTopic(mclTopicName).get().toString(), + MCP_SCHEMA_REGISTRY_TOPIC_KEY + SYSTEM_UPDATE_TOPIC_KEY_ID_SUFFIX, + schemaRegistryService.getSchemaIdForTopic(mcpTopicName).get().toString())); log.info("DataHub System Update Registry"); return new SchemaRegistryConfig( diff --git a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/plugins/SpringStandardPluginConfiguration.java b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/plugins/SpringStandardPluginConfiguration.java index fa4f520dc88c7c..67fe2dd6d605de 100644 --- a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/plugins/SpringStandardPluginConfiguration.java +++ b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/plugins/SpringStandardPluginConfiguration.java @@ -1,26 +1,42 @@ package com.linkedin.gms.factory.plugins; +import static com.linkedin.metadata.Constants.SCHEMA_METADATA_ASPECT_NAME; + +import com.linkedin.metadata.Constants; import com.linkedin.metadata.aspect.hooks.IgnoreUnknownMutator; import com.linkedin.metadata.aspect.plugins.config.AspectPluginConfig; +import com.linkedin.metadata.aspect.plugins.hooks.MCPSideEffect; import com.linkedin.metadata.aspect.plugins.hooks.MutationHook; +import com.linkedin.metadata.schemafields.sideeffects.SchemaFieldSideEffect; +import com.linkedin.metadata.timeline.eventgenerator.EntityChangeEventGeneratorRegistry; +import com.linkedin.metadata.timeline.eventgenerator.SchemaMetadataChangeEventGenerator; import java.util.List; +import lombok.extern.slf4j.Slf4j; import org.springframework.beans.factory.annotation.Value; +import org.springframework.boot.autoconfigure.condition.ConditionalOnProperty; import org.springframework.context.annotation.Bean; import org.springframework.context.annotation.Configuration; @Configuration +@Slf4j public class SpringStandardPluginConfiguration { @Value("${metadataChangeProposal.validation.ignoreUnknown}") private boolean ignoreUnknownEnabled; + @Value("${metadataChangeProposal.validation.extensions.enabled:false}") + private boolean extensionsEnabled; + @Bean + @ConditionalOnProperty( + name = "metadataChangeProposal.validation.extensions.enabled", + havingValue = "false") public MutationHook ignoreUnknownMutator() { return new IgnoreUnknownMutator() .setConfig( AspectPluginConfig.builder() .className(IgnoreUnknownMutator.class.getName()) - .enabled(ignoreUnknownEnabled) + .enabled(ignoreUnknownEnabled && !extensionsEnabled) .supportedOperations(List.of("CREATE", "CREATE_ENTITY", "UPSERT")) .supportedEntityAspectNames( List.of( @@ -30,4 +46,38 @@ public MutationHook ignoreUnknownMutator() { .build())) .build()); } + + @Bean + @ConditionalOnProperty( + name = "metadataChangeProposal.sideEffects.schemaField.enabled", + havingValue = "true") + public MCPSideEffect schemaFieldSideEffect() { + AspectPluginConfig config = + AspectPluginConfig.builder() + .enabled(true) + .className(SchemaFieldSideEffect.class.getName()) + .supportedOperations(List.of("CREATE", "CREATE_ENTITY", "UPSERT", "RESTATE", "DELETE")) + .supportedEntityAspectNames( + List.of( + AspectPluginConfig.EntityAspectName.builder() + .entityName(Constants.DATASET_ENTITY_NAME) + .aspectName(Constants.STATUS_ASPECT_NAME) + .build(), + AspectPluginConfig.EntityAspectName.builder() + .entityName(Constants.DATASET_ENTITY_NAME) + .aspectName(Constants.SCHEMA_METADATA_ASPECT_NAME) + .build())) + .build(); + + // prevent recursive dependency from using primary bean + final EntityChangeEventGeneratorRegistry entityChangeEventGeneratorRegistry = + new EntityChangeEventGeneratorRegistry(); + entityChangeEventGeneratorRegistry.register( + SCHEMA_METADATA_ASPECT_NAME, new SchemaMetadataChangeEventGenerator()); + + log.info("Initialized {}", SchemaFieldSideEffect.class.getName()); + return new SchemaFieldSideEffect() + .setConfig(config) + .setEntityChangeEventGeneratorRegistry(entityChangeEventGeneratorRegistry); + } } diff --git a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/search/LineageSearchServiceFactory.java b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/search/LineageSearchServiceFactory.java index a0df92f6f6bb07..253a79a7b05a81 100644 --- a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/search/LineageSearchServiceFactory.java +++ b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/search/LineageSearchServiceFactory.java @@ -32,6 +32,6 @@ protected LineageSearchService getInstance( graphService, cacheEnabled ? cacheManager.getCache(LINEAGE_SEARCH_SERVICE_CACHE_NAME) : null, cacheEnabled, - configurationProvider.getCache().getSearch().getLineage()); + configurationProvider); } } diff --git a/metadata-service/factories/src/main/java/com/linkedin/metadata/boot/BootstrapStep.java b/metadata-service/factories/src/main/java/com/linkedin/metadata/boot/BootstrapStep.java index 16531466fcddc8..d907f0fe53d06c 100644 --- a/metadata-service/factories/src/main/java/com/linkedin/metadata/boot/BootstrapStep.java +++ b/metadata-service/factories/src/main/java/com/linkedin/metadata/boot/BootstrapStep.java @@ -1,6 +1,9 @@ package com.linkedin.metadata.boot; import com.linkedin.common.urn.Urn; +import com.linkedin.data.template.RecordTemplate; +import com.linkedin.data.template.SetMode; +import com.linkedin.data.template.StringMap; import com.linkedin.events.metadata.ChangeType; import com.linkedin.metadata.Constants; import com.linkedin.metadata.entity.EntityService; @@ -10,8 +13,12 @@ import com.linkedin.metadata.utils.GenericRecordUtils; import com.linkedin.mxe.MetadataChangeProposal; import com.linkedin.upgrade.DataHubUpgradeResult; +import com.linkedin.upgrade.DataHubUpgradeState; import io.datahubproject.metadata.context.OperationContext; +import java.util.Map; +import java.util.Optional; import javax.annotation.Nonnull; +import javax.annotation.Nullable; /** A single step in the Bootstrap process. */ public interface BootstrapStep { @@ -40,10 +47,38 @@ static Urn getUpgradeUrn(String upgradeId) { new DataHubUpgradeKey().setId(upgradeId), Constants.DATA_HUB_UPGRADE_ENTITY_NAME); } + static Optional getUpgradeResult( + @Nonnull OperationContext opContext, Urn urn, EntityService entityService) { + RecordTemplate recordTemplate = + entityService.getLatestAspect( + opContext, urn, Constants.DATA_HUB_UPGRADE_RESULT_ASPECT_NAME); + return Optional.ofNullable(recordTemplate).map(rt -> new DataHubUpgradeResult(rt.data())); + } + static void setUpgradeResult( @Nonnull OperationContext opContext, Urn urn, EntityService entityService) { + setUpgradeResult(opContext, urn, entityService, null); + } + + static void setUpgradeResult( + @Nonnull OperationContext opContext, + Urn urn, + EntityService entityService, + @Nullable Map result) { + setUpgradeResult(opContext, urn, entityService, DataHubUpgradeState.SUCCEEDED, result); + } + + static void setUpgradeResult( + @Nonnull OperationContext opContext, + Urn urn, + EntityService entityService, + @Nullable DataHubUpgradeState state, + @Nullable Map result) { final DataHubUpgradeResult upgradeResult = - new DataHubUpgradeResult().setTimestampMs(System.currentTimeMillis()); + new DataHubUpgradeResult() + .setTimestampMs(System.currentTimeMillis()) + .setState(state, SetMode.IGNORE_NULL) + .setResult(result != null ? new StringMap(result) : null, SetMode.IGNORE_NULL); // Ingest the upgrade result final MetadataChangeProposal upgradeProposal = new MetadataChangeProposal(); diff --git a/metadata-service/factories/src/main/java/com/linkedin/metadata/boot/kafka/MockSystemUpdateSerializer.java b/metadata-service/factories/src/main/java/com/linkedin/metadata/boot/kafka/MockSystemUpdateSerializer.java index 8699695fffbb90..ed2b3c817ed384 100644 --- a/metadata-service/factories/src/main/java/com/linkedin/metadata/boot/kafka/MockSystemUpdateSerializer.java +++ b/metadata-service/factories/src/main/java/com/linkedin/metadata/boot/kafka/MockSystemUpdateSerializer.java @@ -2,6 +2,7 @@ import static com.linkedin.gms.factory.kafka.schemaregistry.SystemUpdateSchemaRegistryFactory.DUHE_SCHEMA_REGISTRY_TOPIC_KEY; import static com.linkedin.gms.factory.kafka.schemaregistry.SystemUpdateSchemaRegistryFactory.MCL_VERSIONED_SCHEMA_REGISTRY_TOPIC_KEY; +import static com.linkedin.gms.factory.kafka.schemaregistry.SystemUpdateSchemaRegistryFactory.MCP_SCHEMA_REGISTRY_TOPIC_KEY; import static com.linkedin.gms.factory.kafka.schemaregistry.SystemUpdateSchemaRegistryFactory.SYSTEM_UPDATE_TOPIC_KEY_ID_SUFFIX; import static com.linkedin.gms.factory.kafka.schemaregistry.SystemUpdateSchemaRegistryFactory.SYSTEM_UPDATE_TOPIC_KEY_PREFIX; import static io.datahubproject.openapi.schema.registry.Constants.FIXED_SCHEMA_VERSION; @@ -27,9 +28,12 @@ public class MockSystemUpdateSerializer extends KafkaAvroSerializer { private static final Map AVRO_SCHEMA_MAP = Map.of( - DUHE_SCHEMA_REGISTRY_TOPIC_KEY, new AvroSchema(EventUtils.ORIGINAL_DUHE_AVRO_SCHEMA), + DUHE_SCHEMA_REGISTRY_TOPIC_KEY, + new AvroSchema(EventUtils.ORIGINAL_DUHE_AVRO_SCHEMA), MCL_VERSIONED_SCHEMA_REGISTRY_TOPIC_KEY, - new AvroSchema(EventUtils.RENAMED_MCL_AVRO_SCHEMA)); + new AvroSchema(EventUtils.RENAMED_MCL_AVRO_SCHEMA), + MCP_SCHEMA_REGISTRY_TOPIC_KEY, + new AvroSchema(EventUtils.RENAMED_MCP_AVRO_SCHEMA)); private Map> topicNameToAvroSchemaMap; diff --git a/metadata-service/factories/src/main/java/com/linkedin/metadata/boot/steps/IngestPoliciesStep.java b/metadata-service/factories/src/main/java/com/linkedin/metadata/boot/steps/IngestPoliciesStep.java index baced32d3826e2..eb6bfe17ac198e 100644 --- a/metadata-service/factories/src/main/java/com/linkedin/metadata/boot/steps/IngestPoliciesStep.java +++ b/metadata-service/factories/src/main/java/com/linkedin/metadata/boot/steps/IngestPoliciesStep.java @@ -20,7 +20,6 @@ import com.linkedin.metadata.query.ListUrnsResult; import com.linkedin.metadata.search.EntitySearchService; import com.linkedin.metadata.search.transformer.SearchDocumentTransformer; -import com.linkedin.metadata.search.utils.SearchUtils; import com.linkedin.metadata.utils.EntityKeyUtils; import com.linkedin.metadata.utils.GenericRecordUtils; import com.linkedin.mxe.GenericAspect; @@ -188,14 +187,11 @@ private void insertPolicyDocument( return; } - Optional docId = SearchUtils.getDocId(entityResponse.getUrn()); - - if (!docId.isPresent()) { - return; - } + final String docId = + _entitySearchService.getIndexConvention().getEntityDocumentId(entityResponse.getUrn()); _entitySearchService.upsertDocument( - systemOperationContext, Constants.POLICY_ENTITY_NAME, searchDocument.get(), docId.get()); + systemOperationContext, Constants.POLICY_ENTITY_NAME, searchDocument.get(), docId); } private void ingestPolicy( diff --git a/metadata-service/graphql-servlet-impl/src/main/java/com/datahub/graphql/GraphQLController.java b/metadata-service/graphql-servlet-impl/src/main/java/com/datahub/graphql/GraphQLController.java index f04f5f80d03a41..2f66b30f55844c 100644 --- a/metadata-service/graphql-servlet-impl/src/main/java/com/datahub/graphql/GraphQLController.java +++ b/metadata-service/graphql-servlet-impl/src/main/java/com/datahub/graphql/GraphQLController.java @@ -15,6 +15,7 @@ import com.linkedin.datahub.graphql.GraphQLEngine; import com.linkedin.datahub.graphql.concurrency.GraphQLConcurrencyUtils; import com.linkedin.datahub.graphql.exception.DataHubGraphQLError; +import com.linkedin.gms.factory.config.ConfigurationProvider; import com.linkedin.metadata.utils.metrics.MetricUtils; import graphql.ExecutionResult; import io.datahubproject.metadata.context.OperationContext; @@ -51,6 +52,8 @@ public GraphQLController() { @Inject AuthorizerChain _authorizerChain; + @Inject ConfigurationProvider configurationProvider; + @Nonnull @Inject @Named("systemOperationContext") @@ -122,6 +125,7 @@ CompletableFuture> postGraphQL( authentication, _authorizerChain, systemOperationContext, + configurationProvider, request, operationName, query, diff --git a/metadata-service/graphql-servlet-impl/src/main/java/com/datahub/graphql/SpringQueryContext.java b/metadata-service/graphql-servlet-impl/src/main/java/com/datahub/graphql/SpringQueryContext.java index 8aa22efb785e25..cd8ce56bf36f92 100644 --- a/metadata-service/graphql-servlet-impl/src/main/java/com/datahub/graphql/SpringQueryContext.java +++ b/metadata-service/graphql-servlet-impl/src/main/java/com/datahub/graphql/SpringQueryContext.java @@ -3,6 +3,7 @@ import com.datahub.authentication.Authentication; import com.datahub.plugins.auth.authorization.Authorizer; import com.linkedin.datahub.graphql.QueryContext; +import com.linkedin.metadata.config.DataHubAppConfiguration; import graphql.language.OperationDefinition; import graphql.parser.Parser; import io.datahubproject.metadata.context.OperationContext; @@ -21,12 +22,14 @@ public class SpringQueryContext implements QueryContext { private final Authorizer authorizer; @Getter private final String queryName; @Nonnull private final OperationContext operationContext; + @Nonnull private final DataHubAppConfiguration dataHubAppConfig; public SpringQueryContext( final boolean isAuthenticated, final Authentication authentication, final Authorizer authorizer, @Nonnull final OperationContext systemOperationContext, + @Nonnull final DataHubAppConfiguration dataHubAppConfig, @Nonnull final HttpServletRequest request, @Nullable final String operationName, String jsonQuery, @@ -57,5 +60,7 @@ public SpringQueryContext( authorizer, authentication, true); + + this.dataHubAppConfig = dataHubAppConfig; } } diff --git a/metadata-service/restli-api/src/main/snapshot/com.linkedin.entity.aspects.snapshot.json b/metadata-service/restli-api/src/main/snapshot/com.linkedin.entity.aspects.snapshot.json index c85e57a35eac7e..3688311b1f2345 100644 --- a/metadata-service/restli-api/src/main/snapshot/com.linkedin.entity.aspects.snapshot.json +++ b/metadata-service/restli-api/src/main/snapshot/com.linkedin.entity.aspects.snapshot.json @@ -3180,7 +3180,7 @@ }, { "name" : "isPartitioningKey", "type" : "boolean", - "doc" : "For Datasets which are partitioned, this determines the partitioning key.", + "doc" : "For Datasets which are partitioned, this determines the partitioning key.\nNote that multiple columns can be part of a partitioning key, but currently we do not support\nrendering the ordered partitioning key.", "optional" : true }, { "name" : "jsonProps", diff --git a/metadata-service/restli-api/src/main/snapshot/com.linkedin.entity.entities.snapshot.json b/metadata-service/restli-api/src/main/snapshot/com.linkedin.entity.entities.snapshot.json index 5b6f7a290fd1a8..59894ed083a2ef 100644 --- a/metadata-service/restli-api/src/main/snapshot/com.linkedin.entity.entities.snapshot.json +++ b/metadata-service/restli-api/src/main/snapshot/com.linkedin.entity.entities.snapshot.json @@ -3572,7 +3572,7 @@ }, { "name" : "isPartitioningKey", "type" : "boolean", - "doc" : "For Datasets which are partitioned, this determines the partitioning key.", + "doc" : "For Datasets which are partitioned, this determines the partitioning key.\nNote that multiple columns can be part of a partitioning key, but currently we do not support\nrendering the ordered partitioning key.", "optional" : true }, { "name" : "jsonProps", @@ -6366,6 +6366,14 @@ }, "doc" : "A list of the the restricted aspects on the entity.\nIf the key aspect is present, assume ALL aspects should be restricted including the entity's Urn.", "optional" : true + }, { + "name" : "extraFields", + "type" : { + "type" : "map", + "values" : "string" + }, + "doc" : "Extra fields from the search document based on what is requested in the search request", + "optional" : true } ] } ], "fields" : [ { diff --git a/metadata-service/restli-api/src/main/snapshot/com.linkedin.entity.runs.snapshot.json b/metadata-service/restli-api/src/main/snapshot/com.linkedin.entity.runs.snapshot.json index dc226adf635c4e..16549757a961fa 100644 --- a/metadata-service/restli-api/src/main/snapshot/com.linkedin.entity.runs.snapshot.json +++ b/metadata-service/restli-api/src/main/snapshot/com.linkedin.entity.runs.snapshot.json @@ -2908,7 +2908,7 @@ }, { "name" : "isPartitioningKey", "type" : "boolean", - "doc" : "For Datasets which are partitioned, this determines the partitioning key.", + "doc" : "For Datasets which are partitioned, this determines the partitioning key.\nNote that multiple columns can be part of a partitioning key, but currently we do not support\nrendering the ordered partitioning key.", "optional" : true }, { "name" : "jsonProps", diff --git a/metadata-service/restli-api/src/main/snapshot/com.linkedin.operations.operations.snapshot.json b/metadata-service/restli-api/src/main/snapshot/com.linkedin.operations.operations.snapshot.json index 7bc02ce2017fd0..95df1d2ce21d93 100644 --- a/metadata-service/restli-api/src/main/snapshot/com.linkedin.operations.operations.snapshot.json +++ b/metadata-service/restli-api/src/main/snapshot/com.linkedin.operations.operations.snapshot.json @@ -2902,7 +2902,7 @@ }, { "name" : "isPartitioningKey", "type" : "boolean", - "doc" : "For Datasets which are partitioned, this determines the partitioning key.", + "doc" : "For Datasets which are partitioned, this determines the partitioning key.\nNote that multiple columns can be part of a partitioning key, but currently we do not support\nrendering the ordered partitioning key.", "optional" : true }, { "name" : "jsonProps", diff --git a/metadata-service/restli-api/src/main/snapshot/com.linkedin.platform.platform.snapshot.json b/metadata-service/restli-api/src/main/snapshot/com.linkedin.platform.platform.snapshot.json index 3f64d1b9480354..3d16550db1e0f1 100644 --- a/metadata-service/restli-api/src/main/snapshot/com.linkedin.platform.platform.snapshot.json +++ b/metadata-service/restli-api/src/main/snapshot/com.linkedin.platform.platform.snapshot.json @@ -3566,7 +3566,7 @@ }, { "name" : "isPartitioningKey", "type" : "boolean", - "doc" : "For Datasets which are partitioned, this determines the partitioning key.", + "doc" : "For Datasets which are partitioned, this determines the partitioning key.\nNote that multiple columns can be part of a partitioning key, but currently we do not support\nrendering the ordered partitioning key.", "optional" : true }, { "name" : "jsonProps", diff --git a/metadata-service/services/src/main/java/com/linkedin/metadata/entity/restoreindices/RestoreIndicesArgs.java b/metadata-service/services/src/main/java/com/linkedin/metadata/entity/restoreindices/RestoreIndicesArgs.java index 89e69174c1502d..cae8c97456c069 100644 --- a/metadata-service/services/src/main/java/com/linkedin/metadata/entity/restoreindices/RestoreIndicesArgs.java +++ b/metadata-service/services/src/main/java/com/linkedin/metadata/entity/restoreindices/RestoreIndicesArgs.java @@ -1,6 +1,8 @@ package com.linkedin.metadata.entity.restoreindices; import java.time.Instant; +import java.util.Collections; +import java.util.List; import lombok.Data; import lombok.experimental.Accessors; @@ -20,6 +22,7 @@ public class RestoreIndicesArgs implements Cloneable { public long gePitEpochMs = DEFAULT_GE_PIT_EPOCH_MS; public long lePitEpochMs; public String aspectName; + public List aspectNames = Collections.emptyList(); public String urn; public String urnLike; public Boolean urnBasedPagination = false; diff --git a/metadata-service/services/src/main/java/com/linkedin/metadata/search/EntitySearchService.java b/metadata-service/services/src/main/java/com/linkedin/metadata/search/EntitySearchService.java index 1b32ddc7c3ecbc..26f2335d0c59fb 100644 --- a/metadata-service/services/src/main/java/com/linkedin/metadata/search/EntitySearchService.java +++ b/metadata-service/services/src/main/java/com/linkedin/metadata/search/EntitySearchService.java @@ -6,6 +6,7 @@ import com.linkedin.metadata.query.AutoCompleteResult; import com.linkedin.metadata.query.filter.Filter; import com.linkedin.metadata.query.filter.SortCriterion; +import com.linkedin.metadata.utils.elasticsearch.IndexConvention; import io.datahubproject.metadata.context.OperationContext; import java.util.List; import java.util.Map; @@ -321,4 +322,11 @@ ExplainResponse explain( @Nullable String keepAlive, int size, @Nullable List facets); + + /** + * Return index convention + * + * @return convent + */ + IndexConvention getIndexConvention(); } diff --git a/metadata-service/services/src/main/java/com/linkedin/metadata/search/utils/QueryUtils.java b/metadata-service/services/src/main/java/com/linkedin/metadata/search/utils/QueryUtils.java index a148a45b20e0c7..730a2886ab2bf0 100644 --- a/metadata-service/services/src/main/java/com/linkedin/metadata/search/utils/QueryUtils.java +++ b/metadata-service/services/src/main/java/com/linkedin/metadata/search/utils/QueryUtils.java @@ -4,9 +4,11 @@ import com.datahub.util.ModelUtils; import com.google.common.collect.ImmutableList; +import com.linkedin.common.urn.Urn; import com.linkedin.data.template.RecordTemplate; import com.linkedin.data.template.StringArray; import com.linkedin.metadata.aspect.AspectVersion; +import com.linkedin.metadata.config.DataHubAppConfiguration; import com.linkedin.metadata.models.EntitySpec; import com.linkedin.metadata.models.SearchableFieldSpec; import com.linkedin.metadata.models.annotation.SearchableAnnotation; @@ -20,14 +22,17 @@ import com.linkedin.metadata.query.filter.RelationshipDirection; import com.linkedin.metadata.query.filter.RelationshipFilter; import com.linkedin.util.Pair; +import java.util.Arrays; import java.util.Collections; import java.util.List; import java.util.Map; import java.util.Objects; import java.util.Set; import java.util.stream.Collectors; +import java.util.stream.Stream; import javax.annotation.Nonnull; import javax.annotation.Nullable; +import org.apache.commons.collections.CollectionUtils; public class QueryUtils { @@ -87,6 +92,25 @@ public static Filter newFilter(@Nonnull Criterion criterion) { .setAnd(new CriterionArray(ImmutableList.of(criterion)))))); } + @Nonnull + public static Filter newDisjunctiveFilter(@Nonnull Criterion... orCriterion) { + return new Filter() + .setOr( + Arrays.stream(orCriterion) + .map( + criterion -> + new ConjunctiveCriterion() + .setAnd(new CriterionArray(ImmutableList.of(criterion)))) + .collect(Collectors.toCollection(ConjunctiveCriterionArray::new))); + } + + @Nonnull + public static ConjunctiveCriterion add( + @Nonnull ConjunctiveCriterion conjunctiveCriterion, @Nonnull Criterion element) { + conjunctiveCriterion.getAnd().add(element); + return conjunctiveCriterion; + } + @Nonnull public static Filter filterOrDefaultEmptyFilter(@Nullable Filter filter) { return filter != null ? filter : EMPTY_FILTER; @@ -195,4 +219,77 @@ public static List getQueryByDefaultEntitySpecs(EntityRegistry entit .map(Pair::getFirst) .collect(Collectors.toList()); } + + /** + * Build a filter with URNs and an optional existing filter + * + * @param urns urns to limit returns + * @param inputFilters optional existing filter + * @return filter with additional URN criterion + */ + public static Filter buildFilterWithUrns( + @Nonnull DataHubAppConfiguration appConfig, + @Nonnull Set urns, + @Nullable Filter inputFilters) { + // Determine which field is used for urn selection based on config + boolean schemaFieldEnabled = + appConfig.getMetadataChangeProposal().getSideEffects().getSchemaField().isEnabled(); + + // Prevent increasing the query size by avoiding querying multiple fields with the + // same URNs + Criterion urnMatchCriterion = + new Criterion() + .setField("urn") + .setValue("") + .setValues( + new StringArray( + urns.stream() + .filter( + urn -> + !schemaFieldEnabled + || !urn.getEntityType().equals(SCHEMA_FIELD_ENTITY_NAME)) + .map(Object::toString) + .collect(Collectors.toList()))); + + Criterion schemaUrnAliasCriterion = + new Criterion() + .setField(String.format("%s.keyword", SCHEMA_FIELD_ALIASES_ASPECT)) + .setValue("") + .setValues( + new StringArray( + urns.stream() + .filter( + urn -> + schemaFieldEnabled + && urn.getEntityType().equals(SCHEMA_FIELD_ENTITY_NAME)) + .map(Object::toString) + .collect(Collectors.toList()))); + + if (inputFilters == null || CollectionUtils.isEmpty(inputFilters.getOr())) { + return QueryUtils.newDisjunctiveFilter(urnMatchCriterion, schemaUrnAliasCriterion); + } + + // Add urn match criterion to each or clause + inputFilters.setOr( + inputFilters.getOr().stream() + .flatMap( + existingCriterion -> { + try { + return Stream.concat( + urnMatchCriterion.getValues().isEmpty() + ? Stream.of() + : Stream.of( + QueryUtils.add(existingCriterion.copy(), urnMatchCriterion)), + schemaUrnAliasCriterion.getValues().isEmpty() + ? Stream.of() + : Stream.of( + QueryUtils.add(existingCriterion.copy(), schemaUrnAliasCriterion))); + } catch (CloneNotSupportedException e) { + throw new RuntimeException(e); + } + }) + .collect(Collectors.toCollection(ConjunctiveCriterionArray::new))); + + return inputFilters; + } } diff --git a/metadata-service/services/src/main/java/com/linkedin/metadata/service/FormService.java b/metadata-service/services/src/main/java/com/linkedin/metadata/service/FormService.java index 210fba82eb4e20..b702a618404230 100644 --- a/metadata-service/services/src/main/java/com/linkedin/metadata/service/FormService.java +++ b/metadata-service/services/src/main/java/com/linkedin/metadata/service/FormService.java @@ -312,7 +312,7 @@ private void ingestSchemaFieldStructuredProperties( @Nonnull final PrimitivePropertyValueArray values, @Nonnull final String fieldPath) throws Exception { - Urn schemaFieldUrn = SchemaFieldUtils.generateSchemaFieldUrn(entityUrn.toString(), fieldPath); + Urn schemaFieldUrn = SchemaFieldUtils.generateSchemaFieldUrn(entityUrn, fieldPath); ingestStructuredProperties(opContext, schemaFieldUrn, structuredPropertyUrn, values); } diff --git a/metadata-service/services/src/main/java/com/linkedin/metadata/timeline/data/ChangeTransaction.java b/metadata-service/services/src/main/java/com/linkedin/metadata/timeline/data/ChangeTransaction.java index 3e963dba0cdb4c..f34c20e6acd763 100644 --- a/metadata-service/services/src/main/java/com/linkedin/metadata/timeline/data/ChangeTransaction.java +++ b/metadata-service/services/src/main/java/com/linkedin/metadata/timeline/data/ChangeTransaction.java @@ -1,8 +1,8 @@ package com.linkedin.metadata.timeline.data; -import com.github.fge.jsonpatch.JsonPatch; import io.swagger.v3.oas.annotations.media.ArraySchema; import io.swagger.v3.oas.annotations.media.Schema; +import jakarta.json.JsonPatch; import java.util.List; import lombok.Builder; import lombok.Getter; diff --git a/metadata-utils/src/main/java/com/linkedin/metadata/utils/SchemaFieldUtils.java b/metadata-utils/src/main/java/com/linkedin/metadata/utils/SchemaFieldUtils.java index edf959d04a37b3..4515008b050a1b 100644 --- a/metadata-utils/src/main/java/com/linkedin/metadata/utils/SchemaFieldUtils.java +++ b/metadata-utils/src/main/java/com/linkedin/metadata/utils/SchemaFieldUtils.java @@ -1,22 +1,124 @@ package com.linkedin.metadata.utils; +import static com.linkedin.metadata.Constants.SCHEMA_FIELD_ENTITY_NAME; +import static org.apache.commons.codec.digest.DigestUtils.sha256Hex; + +import com.google.common.annotations.VisibleForTesting; import com.linkedin.common.urn.Urn; import com.linkedin.common.urn.UrnUtils; -import com.linkedin.metadata.Constants; -import com.linkedin.metadata.key.SchemaFieldKey; +import com.linkedin.schema.SchemaField; +import com.linkedin.schema.SchemaMetadata; +import com.linkedin.util.Pair; +import java.util.Arrays; +import java.util.HashSet; +import java.util.Set; +import java.util.stream.Collectors; import javax.annotation.Nonnull; public class SchemaFieldUtils { + private static final String FIELD_PATH_V2 = "[version=2.0]"; private SchemaFieldUtils() {} + /** + * Generate schemaFieldUrn from the parent dataset urn from schemaMetadata field + * + * @param parentUrn the dataset's urn + * @param field field from schemaMetadata + * @return schemaField URN + */ + public static Urn generateSchemaFieldUrn(Urn parentUrn, SchemaField field) { + return generateSchemaFieldUrn(parentUrn, field.getFieldPath()); + } + + public static String generateDocumentId(Urn schemaFieldUrn) { + if (!SCHEMA_FIELD_ENTITY_NAME.equals(schemaFieldUrn.getEntityType())) { + throw new IllegalArgumentException( + String.format( + "Invalid URN, expected entity %s, found %s", + SCHEMA_FIELD_ENTITY_NAME, schemaFieldUrn.getEntityType())); + } + + return String.format( + "urn:li:%s:(%s,%s)", + SCHEMA_FIELD_ENTITY_NAME, + sha256Hex(schemaFieldUrn.getEntityKey().get(0)), + sha256Hex(schemaFieldUrn.getEntityKey().get(1))); + } + + /** + * Handles our url encoding for URN characters. + * + * @param parentUrn the dataset's urn + * @param fieldPath field path + * @return schemaField URN + */ public static Urn generateSchemaFieldUrn( - @Nonnull final String resourceUrn, @Nonnull final String fieldPath) { + @Nonnull final Urn parentUrn, @Nonnull final String fieldPath) { // we rely on schemaField fieldPaths to be encoded since we do that on the ingestion side final String encodedFieldPath = fieldPath.replaceAll("\\(", "%28").replaceAll("\\)", "%29").replaceAll(",", "%2C"); - final SchemaFieldKey key = - new SchemaFieldKey().setParent(UrnUtils.getUrn(resourceUrn)).setFieldPath(encodedFieldPath); - return EntityKeyUtils.convertEntityKeyToUrn(key, Constants.SCHEMA_FIELD_ENTITY_NAME); + return Urn.createFromTuple(SCHEMA_FIELD_ENTITY_NAME, parentUrn.toString(), encodedFieldPath); + } + + /** + * Produce schemaField URN aliases v1/v2 variants given a schemeField target URN (either v1/v2), + * the parent dataset URN and the parent dataset's schemaMetadata aspect. + * + * @param datasetUrn parent dataset's urn + * @param schemaMetadata parent dataset's schemaMetadata + * @param schemaField target schemeField + * @return all aliases of the given schemaField URN including itself (if it exists within the + * schemaMetadata) + */ + public static Set getSchemaFieldAliases( + @Nonnull Urn datasetUrn, + @Nonnull SchemaMetadata schemaMetadata, + @Nonnull SchemaField schemaField) { + + Urn downgradedUrn = + downgradeSchemaFieldUrn( + generateSchemaFieldUrn(datasetUrn, downgradeFieldPath(schemaField.getFieldPath()))); + + // Find all collisions after v2 -> v1 conversion + HashSet aliases = + schemaMetadata.getFields().stream() + .map( + field -> + Pair.of( + generateSchemaFieldUrn( + datasetUrn, downgradeFieldPath(field.getFieldPath())), + generateSchemaFieldUrn(datasetUrn, field.getFieldPath()))) + .filter(pair -> pair.getFirst().equals(downgradedUrn)) + .map(Pair::getSecond) + .collect(Collectors.toCollection(HashSet::new)); + + if (!aliases.isEmpty()) { + // if v2 -> v1 + aliases.add(downgradedUrn); + } + + return aliases; + } + + @VisibleForTesting + @Nonnull + static Urn downgradeSchemaFieldUrn(@Nonnull Urn schemaFieldUrn) { + return generateSchemaFieldUrn( + UrnUtils.getUrn(schemaFieldUrn.getId()), + downgradeFieldPath(schemaFieldUrn.getEntityKey().get(1))); + } + + // https://datahubproject.io/docs/advanced/field-path-spec-v2/#backward-compatibility + @Nonnull + private static String downgradeFieldPath(@Nonnull String fieldPath) { + if (fieldPath.startsWith(FIELD_PATH_V2)) { + return Arrays.stream(fieldPath.substring(FIELD_PATH_V2.length()).split("[.]")) + .filter( + component -> + !component.isEmpty() && !(component.startsWith("[") && component.endsWith("]"))) + .collect(Collectors.joining(".")); + } + return fieldPath; } } diff --git a/metadata-utils/src/main/java/com/linkedin/metadata/utils/elasticsearch/IndexConvention.java b/metadata-utils/src/main/java/com/linkedin/metadata/utils/elasticsearch/IndexConvention.java index 87aebabf643666..b4c95ce106de5f 100644 --- a/metadata-utils/src/main/java/com/linkedin/metadata/utils/elasticsearch/IndexConvention.java +++ b/metadata-utils/src/main/java/com/linkedin/metadata/utils/elasticsearch/IndexConvention.java @@ -1,5 +1,6 @@ package com.linkedin.metadata.utils.elasticsearch; +import com.linkedin.common.urn.Urn; import com.linkedin.data.template.RecordTemplate; import com.linkedin.metadata.models.EntitySpec; import com.linkedin.util.Pair; @@ -50,4 +51,13 @@ public interface IndexConvention { @Nonnull String getIdHashAlgo(); + + /** + * Given the URN generate the document id for entity indices + * + * @param entityUrn the entity which the document belongs + * @return document id + */ + @Nonnull + String getEntityDocumentId(Urn entityUrn); } diff --git a/metadata-utils/src/main/java/com/linkedin/metadata/utils/elasticsearch/IndexConventionImpl.java b/metadata-utils/src/main/java/com/linkedin/metadata/utils/elasticsearch/IndexConventionImpl.java index 2c9c927cd8c347..5855715fb7ebab 100644 --- a/metadata-utils/src/main/java/com/linkedin/metadata/utils/elasticsearch/IndexConventionImpl.java +++ b/metadata-utils/src/main/java/com/linkedin/metadata/utils/elasticsearch/IndexConventionImpl.java @@ -1,20 +1,28 @@ package com.linkedin.metadata.utils.elasticsearch; +import static com.linkedin.metadata.Constants.SCHEMA_FIELD_ENTITY_NAME; + +import com.linkedin.common.urn.Urn; import com.linkedin.data.template.RecordTemplate; import com.linkedin.metadata.models.EntitySpec; +import com.linkedin.metadata.utils.SchemaFieldUtils; import com.linkedin.util.Pair; +import java.net.URLEncoder; +import java.nio.charset.StandardCharsets; import java.util.Map; import java.util.Optional; import java.util.concurrent.ConcurrentHashMap; import javax.annotation.Nonnull; import javax.annotation.Nullable; +import lombok.Builder; import lombok.Getter; +import lombok.Value; import org.apache.commons.lang3.StringUtils; // Default implementation of search index naming convention public class IndexConventionImpl implements IndexConvention { public static IndexConvention noPrefix(@Nonnull String idHashAlgo) { - return new IndexConventionImpl(null, idHashAlgo); + return new IndexConventionImpl(IndexConventionConfig.builder().hashIdAlgo(idHashAlgo).build()); } // Map from Entity name -> Index name @@ -22,16 +30,19 @@ public static IndexConvention noPrefix(@Nonnull String idHashAlgo) { private final Optional _prefix; private final String _getAllEntityIndicesPattern; private final String _getAllTimeseriesIndicesPattern; - @Getter private final String idHashAlgo; + @Getter private final IndexConventionConfig indexConventionConfig; private static final String ENTITY_INDEX_VERSION = "v2"; private static final String ENTITY_INDEX_SUFFIX = "index"; private static final String TIMESERIES_INDEX_VERSION = "v1"; private static final String TIMESERIES_ENTITY_INDEX_SUFFIX = "aspect"; - public IndexConventionImpl(@Nullable String prefix, String idHashAlgo) { - _prefix = StringUtils.isEmpty(prefix) ? Optional.empty() : Optional.of(prefix); - this.idHashAlgo = idHashAlgo; + public IndexConventionImpl(IndexConventionConfig indexConventionConfig) { + this.indexConventionConfig = indexConventionConfig; + _prefix = + StringUtils.isEmpty(indexConventionConfig.getPrefix()) + ? Optional.empty() + : Optional.of(indexConventionConfig.getPrefix()); _getAllEntityIndicesPattern = _prefix.map(p -> p + "_").orElse("") + "*" @@ -46,6 +57,12 @@ public IndexConventionImpl(@Nullable String prefix, String idHashAlgo) { + TIMESERIES_INDEX_VERSION; } + @Nonnull + @Override + public String getIdHashAlgo() { + return indexConventionConfig.getHashIdAlgo(); + } + private String createIndexName(String baseName) { return (_prefix.map(prefix -> prefix + "_").orElse("") + baseName).toLowerCase(); } @@ -136,4 +153,27 @@ public Optional> getEntityAndAspectName(String timeseriesAs } return Optional.empty(); } + + @Nonnull + @Override + public String getEntityDocumentId(Urn entityUrn) { + final String unencodedId; + if (indexConventionConfig.schemaFieldDocIdHashEnabled + && SCHEMA_FIELD_ENTITY_NAME.equals(entityUrn.getEntityType())) { + unencodedId = SchemaFieldUtils.generateDocumentId(entityUrn); + } else { + unencodedId = entityUrn.toString(); + } + + return URLEncoder.encode(unencodedId, StandardCharsets.UTF_8); + } + + /** Since this is used outside of Spring */ + @Value + @Builder + public static class IndexConventionConfig { + @Builder.Default String hashIdAlgo = "MD5"; + @Builder.Default @Nullable String prefix = null; + @Builder.Default boolean schemaFieldDocIdHashEnabled = false; + } } diff --git a/metadata-utils/src/test/java/com/linkedin/metadata/utils/SchemaFieldUtilsTest.java b/metadata-utils/src/test/java/com/linkedin/metadata/utils/SchemaFieldUtilsTest.java new file mode 100644 index 00000000000000..53f24f1d99b959 --- /dev/null +++ b/metadata-utils/src/test/java/com/linkedin/metadata/utils/SchemaFieldUtilsTest.java @@ -0,0 +1,133 @@ +package com.linkedin.metadata.utils; + +import static org.testng.Assert.assertEquals; + +import com.linkedin.common.urn.Urn; +import com.linkedin.common.urn.UrnUtils; +import com.linkedin.schema.SchemaField; +import com.linkedin.schema.SchemaFieldArray; +import com.linkedin.schema.SchemaMetadata; +import java.util.List; +import java.util.Set; +import org.testng.annotations.Test; + +/** Tests the capabilities of {@link EntityKeyUtils} */ +public class SchemaFieldUtilsTest { + private static final Urn TEST_DATASET_URN = + UrnUtils.getUrn( + "urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD)"); + + @Test + public void testGenerateSchemaFieldURN() { + assertEquals( + SchemaFieldUtils.generateSchemaFieldUrn(TEST_DATASET_URN, "customer_id"), + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD),customer_id)")); + + assertEquals( + SchemaFieldUtils.generateSchemaFieldUrn( + TEST_DATASET_URN, + "[version=2.0].[type=ABFooUnion].[type=union].[type=array].[type=array].[type=Foo].a.[type=long].f"), + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD),[version=2.0].[type=ABFooUnion].[type=union].[type=array].[type=array].[type=Foo].a.[type=long].f)")); + } + + @Test + public void testDowngradeSchemaFieldUrn() { + assertEquals( + SchemaFieldUtils.downgradeSchemaFieldUrn( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD),customer_id)")), + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD),customer_id)"), + "Expected no change to v1 field path schemaField URN"); + + assertEquals( + SchemaFieldUtils.downgradeSchemaFieldUrn( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD),[version=2.0].[type=ABFooUnion].[type=union].[type=array].[type=array].[type=Foo].a.[type=long].f)")), + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD),a.f)"), + "Expected downgrade to v1 field path schemaField URN"); + } + + @Test + public void testSchemaFieldAliases() { + SchemaMetadata testSchema = new SchemaMetadata(); + testSchema.setFields( + new SchemaFieldArray( + List.of( + new SchemaField().setFieldPath("customer_id"), + new SchemaField().setFieldPath("[version=2.0].[type=ABFooUnion].[type=union].a"), + new SchemaField() + .setFieldPath("[version=2.0].[type=ABFooUnion].[type=union].[type=A].a"), + new SchemaField() + .setFieldPath( + "[version=2.0].[type=ABFooUnion].[type=union].[type=A].a.[type=string].f"), + new SchemaField() + .setFieldPath("[version=2.0].[type=ABFooUnion].[type=union].[type=B].a"), + new SchemaField() + .setFieldPath( + "[version=2.0].[type=ABFooUnion].[type=union].[type=B].a.[type=string].f"), + new SchemaField() + .setFieldPath( + "[version=2.0].[type=ABFooUnion].[type=union].[type=array].[type=array].[type=Foo].a"), + new SchemaField() + .setFieldPath( + "[version=2.0].[type=ABFooUnion].[type=union].[type=array].[type=array].[type=Foo].a.[type=long].f")))); + + assertEquals( + SchemaFieldUtils.getSchemaFieldAliases( + TEST_DATASET_URN, testSchema, new SchemaField().setFieldPath("customer_id")), + Set.of( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD),customer_id)")), + "Expected only the target v1 schemaField and no aliases"); + + assertEquals( + SchemaFieldUtils.getSchemaFieldAliases( + TEST_DATASET_URN, + testSchema, + new SchemaField().setFieldPath("[version=2.0].[type=ABFooUnion].[type=union].a")), + Set.of( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD),[version=2.0].[type=ABFooUnion].[type=union].a)"), + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD),a)"), + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD),[version=2.0].[type=ABFooUnion].[type=union].[type=A].a)"), + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD),[version=2.0].[type=ABFooUnion].[type=union].[type=B].a)"), + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD),[version=2.0].[type=ABFooUnion].[type=union].[type=array].[type=array].[type=Foo].a)")), + "Expected one v1 alias and 3 collisions. Excluding target"); + + assertEquals( + SchemaFieldUtils.getSchemaFieldAliases( + TEST_DATASET_URN, + testSchema, + new SchemaField() + .setFieldPath( + "[version=2.0].[type=ABFooUnion].[type=union].[type=array].[type=array].[type=Foo].a.[type=long].f")), + Set.of( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD),[version=2.0].[type=ABFooUnion].[type=union].[type=array].[type=array].[type=Foo].a.[type=long].f)"), + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD),a.f)"), + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD),[version=2.0].[type=ABFooUnion].[type=union].[type=A].a.[type=string].f)"), + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,cypress_project.jaffle_shop.customers,PROD),[version=2.0].[type=ABFooUnion].[type=union].[type=B].a.[type=string].f)")), + "Expected one v1 alias and 2 collisions. Excluding target"); + + assertEquals( + SchemaFieldUtils.getSchemaFieldAliases( + TEST_DATASET_URN, + testSchema, + new SchemaField() + .setFieldPath( + "[version=2.0].[type=ABFooUnion].[type=union].[type=array].[type=array].[type=Foo].a.[type=long].z")), + Set.of(), + "Expected no aliases since target field is not present."); + } +} diff --git a/metadata-utils/src/test/java/com/linkedin/metadata/utils/elasticsearch/IndexConventionImplTest.java b/metadata-utils/src/test/java/com/linkedin/metadata/utils/elasticsearch/IndexConventionImplTest.java index 2f6c7138d3c4fb..8768c44c70a82d 100644 --- a/metadata-utils/src/test/java/com/linkedin/metadata/utils/elasticsearch/IndexConventionImplTest.java +++ b/metadata-utils/src/test/java/com/linkedin/metadata/utils/elasticsearch/IndexConventionImplTest.java @@ -1,8 +1,11 @@ package com.linkedin.metadata.utils.elasticsearch; +import static org.apache.commons.codec.digest.DigestUtils.sha256Hex; import static org.testng.Assert.*; +import com.linkedin.common.urn.UrnUtils; import com.linkedin.util.Pair; +import java.net.URLEncoder; import java.util.Optional; import org.testng.annotations.Test; @@ -25,7 +28,12 @@ public void testIndexConventionNoPrefix() { @Test public void testIndexConventionPrefix() { - IndexConvention indexConventionPrefix = new IndexConventionImpl("prefix", "MD5"); + IndexConvention indexConventionPrefix = + new IndexConventionImpl( + IndexConventionImpl.IndexConventionConfig.builder() + .prefix("prefix") + .hashIdAlgo("MD5") + .build()); String entityName = "dataset"; String expectedIndexName = "prefix_datasetindex_v2"; assertEquals(indexConventionPrefix.getEntityIndexName(entityName), expectedIndexName); @@ -64,7 +72,12 @@ public void testTimeseriesIndexConventionNoPrefix() { @Test public void testTimeseriesIndexConventionPrefix() { - IndexConvention indexConventionPrefix = new IndexConventionImpl("prefix", "MD5"); + IndexConvention indexConventionPrefix = + new IndexConventionImpl( + IndexConventionImpl.IndexConventionConfig.builder() + .prefix("prefix") + .hashIdAlgo("MD5") + .build()); String entityName = "dataset"; String aspectName = "datasetusagestatistics"; String expectedIndexName = "prefix_dataset_datasetusagestatisticsaspect_v1"; @@ -81,4 +94,24 @@ public void testTimeseriesIndexConventionPrefix() { indexConventionPrefix.getEntityAndAspectName("prefix_datasetusagestatisticsaspect_v1"), Optional.empty()); } + + @Test + public void testSchemaFieldDocumentId() { + assertEquals( + new IndexConventionImpl( + IndexConventionImpl.IndexConventionConfig.builder() + .prefix("") + .hashIdAlgo("") + .schemaFieldDocIdHashEnabled(true) + .build()) + .getEntityDocumentId( + UrnUtils.getUrn( + "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:snowflake,economic_data.factor_income,PROD),year)")), + URLEncoder.encode( + String.format( + "urn:li:schemaField:(%s,%s)", + sha256Hex( + "urn:li:dataset:(urn:li:dataPlatform:snowflake,economic_data.factor_income,PROD)"), + sha256Hex("year")))); + } } diff --git a/smoke-test/tests/schema_fields/schema_evolution.py b/smoke-test/tests/schema_fields/schema_evolution.py new file mode 100644 index 00000000000000..256ae3c29ac04d --- /dev/null +++ b/smoke-test/tests/schema_fields/schema_evolution.py @@ -0,0 +1,230 @@ +import time +from enum import Enum + +import datahub.metadata.schema_classes as models +import pytest +from datahub.cli.cli_utils import get_aspects_for_entity +from datahub.emitter.mce_builder import make_dataset_urn, make_schema_field_urn +from datahub.emitter.mcp import MetadataChangeProposalWrapper +from datahub.ingestion.graph.client import DataHubGraph, get_default_graph +from tenacity import retry, stop_after_delay, wait_fixed + +from tests.utils import get_datahub_graph, ingest_file_via_rest, wait_for_writes_to_sync + +_MAX_DELAY_UNTIL_WRITES_VISIBLE_SECS = 30 +_ATTEMPT_RETRY_INTERVAL_SECS = 1 +large_dataset_urn = "urn:li:dataset:(urn:li:dataPlatform:looker,test-large-schema,PROD)" + + +class FieldPathStyle(Enum): + FLAT = "FLAT" + NESTED = "NESTED" + + +def _create_schema_with_fields( + entity_urn: str, + num_fields: int = 1, + field_path_style: FieldPathStyle = FieldPathStyle.FLAT, +) -> models.SchemaMetadataClass: + """ + A simple helper function to create a schema with a given number of fields. + The fields are created with the following naming convention: + - FLAT: field_0, field_1, field_2, ... + - NESTED: [version=2.0].[type=Address].parent_field.[type=string].field_0, + [version=2.0].[type=Address].parent_field.[type=string].field_1, ... + + TODO: Add support for more complex field types and descriptions beyond + strings. + """ + + schema = models.SchemaMetadataClass( + schemaName="my_schema", + platformSchema=models.OtherSchemaClass(rawSchema=""), + platform="urn:li:dataPlatform:bigquery", + version=0, + hash="", + fields=[ + models.SchemaFieldClass( + fieldPath=( + f"field_{i}" + if field_path_style == FieldPathStyle.FLAT + else f"[version=2.0].[type=Address].parent_field.[type=string].field_{i}" + ), + nativeDataType="STRING", + type=models.SchemaFieldDataTypeClass(type=models.StringTypeClass()), + description="", + nullable=True, + ) + for i in range(num_fields) + ], + ) + assert schema.validate() + return schema + + +@pytest.fixture(autouse=False) +def test_setup(): + """Fixture data""" + client = get_datahub_graph() + session = client._session + gms_host = client.config.server + + ingest_file_via_rest( + "tests/schema_fields/schema_field_side_effect_data.json" + ).config.run_id + + assert "schemaMetadata" in get_aspects_for_entity( + session, + gms_host, + entity_urn=large_dataset_urn, + aspects=["schemaMetadata"], + typed=False, + ) + + yield + # Deleting takes way too long for CI + # + # rollback_url = f"{gms_host}/runs?action=rollback" + # session.post( + # rollback_url, + # data=json.dumps( + # {"runId": ingested_dataset_run_id, "dryRun": False, "hardDelete": True} + # ), + # ) + # + # wait_for_writes_to_sync() + # + # assert "schemaMetadata" not in get_aspects_for_entity( + # entity_urn=large_dataset_urn, aspects=["schemaMetadata"], typed=False + # ) + + +@retry( + stop=stop_after_delay(_MAX_DELAY_UNTIL_WRITES_VISIBLE_SECS), + wait=wait_fixed(_ATTEMPT_RETRY_INTERVAL_SECS), + reraise=True, +) +def assert_schema_field_exists(graph: DataHubGraph, urn: str, field_path: str): + schema_field_urn = make_schema_field_urn(parent_urn=urn, field_path=field_path) + assert graph.exists(schema_field_urn) + status = graph.get_aspect(schema_field_urn, models.StatusClass) + assert status is None or status.removed is False + + +@retry( + stop=stop_after_delay(_MAX_DELAY_UNTIL_WRITES_VISIBLE_SECS), + wait=wait_fixed(_ATTEMPT_RETRY_INTERVAL_SECS), + reraise=True, +) +def assert_schema_field_soft_deleted(graph: DataHubGraph, urn: str, field_path: str): + schema_field_urn = make_schema_field_urn(parent_urn=urn, field_path=field_path) + status = graph.get_aspect(schema_field_urn, models.StatusClass) + assert status and status.removed is True + + +@pytest.mark.parametrize( + "field_path_style", + [ + FieldPathStyle.NESTED, + FieldPathStyle.FLAT, + ], +) +def test_schema_evolution_field_dropped(field_path_style: FieldPathStyle): + """ + Test that schema evolution works as expected + 1. Create a schema with 2 fields + 2. Sleep for 10 seconds + 3. Update the schema to have 1 field + 4. Sleep for 10 seconds + 5. Assert that the field_1 is removed + """ + + now = int(time.time()) + + urn = make_dataset_urn("bigquery", f"my_dataset.my_table.{now}") + print(urn) + with get_default_graph() as graph: + schema_with_2_fields = _create_schema_with_fields( + urn, 2, field_path_style=field_path_style + ) + field_names = [field.fieldPath for field in schema_with_2_fields.fields] + graph.emit( + MetadataChangeProposalWrapper( + entityUrn=urn, + aspect=schema_with_2_fields, + ) + ) + + for field_name in field_names: + print("Checking field: ", field_name) + assert_schema_field_exists(graph, urn, field_name) + + # Evolve the schema + schema_with_1_field = _create_schema_with_fields( + urn, 1, field_path_style=field_path_style + ) + new_field_name = schema_with_1_field.fields[0].fieldPath + + field_names.remove(new_field_name) + removed_field_name = field_names[0] + + graph.emit( + MetadataChangeProposalWrapper( + entityUrn=urn, + aspect=schema_with_1_field, + ) + ) + + assert_schema_field_exists(graph, urn, new_field_name) + assert_schema_field_soft_deleted(graph, urn, removed_field_name) + + +def test_soft_deleted_entity(): + """ + Test that we if there is a soft deleted dataset, its schema fields are + initialized with soft deleted status + 1. Create a schema with 2 fields + """ + + now = int(time.time()) + + urn = make_dataset_urn("bigquery", f"my_dataset.my_table.{now}") + print(urn) + with get_default_graph() as graph: + schema_with_2_fields = _create_schema_with_fields(urn, 2) + field_names = [field.fieldPath for field in schema_with_2_fields.fields] + graph.emit( + MetadataChangeProposalWrapper( + entityUrn=urn, + aspect=schema_with_2_fields, + ) + ) + + for field_name in field_names: + print("Checking field: ", field_name) + assert_schema_field_exists(graph, urn, field_name) + + # Soft delete the dataset + graph.emit( + MetadataChangeProposalWrapper( + entityUrn=urn, + aspect=models.StatusClass(removed=True), + ) + ) + + # Check that the fields are soft deleted + for field_name in field_names: + assert_schema_field_soft_deleted(graph, urn, field_name) + + +# Note: Does not execute deletes, too slow for CI +@pytest.mark.dependency() +def test_large_schema(test_setup): + wait_for_writes_to_sync() + with get_default_graph() as graph: + assert_schema_field_exists(graph, large_dataset_urn, "last_of.6800_cols") + + +if __name__ == "__main__": + test_schema_evolution_field_dropped() + test_soft_deleted_entity() diff --git a/smoke-test/tests/schema_fields/schema_field_side_effect_data.json b/smoke-test/tests/schema_fields/schema_field_side_effect_data.json new file mode 100644 index 00000000000000..8d40a1df1be5dd --- /dev/null +++ b/smoke-test/tests/schema_fields/schema_field_side_effect_data.json @@ -0,0 +1,153085 @@ +[ + { + "auditHeader": null, + "proposedSnapshot": { + "com.linkedin.pegasus2avro.metadata.snapshot.DatasetSnapshot": { + "urn": "urn:li:dataset:(urn:li:dataPlatform:looker,test-large-schema,PROD)", + "aspects": [ + { + "com.linkedin.pegasus2avro.schema.SchemaMetadata": { + "primaryKeys": [], + "platformSchema": { + "com.linkedin.schema.OtherSchema": { + "rawSchema": "" + } + }, + "created": { + "actor": "urn:li:corpuser:unknown", + "time": 0 + }, + "lastModified": { + "actor": "urn:li:corpuser:unknown", + "time": 0 + }, + "fields": [ + { + "nullable": false, + "fieldPath": "m_c_i_c.e_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.e_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.e_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.e_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.e_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.e_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.e_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.e_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.e_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.e_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.e_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.e_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.e_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.e_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.e_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.e_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.e_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_c_i_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_c_i_c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_c_i_c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_c_i_c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_c_i_c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_c_i_c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_i_i_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_i_i_c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_i_i_c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_i_i_c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_i_i_c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_i_i_c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_o_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_o_c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_o_c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_o_c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_o_c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_o_c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_a_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_q_t_a_c_q_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.h_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.h_a_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.h_a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.h_a_l_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.h_a_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.h_a_w_l_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.h_b_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.h_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.h_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.h_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.h_s_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.h_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_h.e_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_h.c_f_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_a_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_a_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c_i_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c_i_c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c_i_c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c_i_c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c_i_c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c_i_c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_i_i_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_i_i_c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_i_i_c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_i_i_c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_i_i_c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_i_i_c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c_t_a_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c_r_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.l_c_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.l_c_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.m_c_w_3_d_o_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.m_d_a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.m_t_a_i_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.m_t_d_a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.o_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.s_c_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.s_c_i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.v_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.v_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.w_l_c_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.w_l_c_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.a_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_i.e_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m_c_i.f_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.f_i_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.f_i_c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.f_i_c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.f_i_c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.f_i_c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.f_i_c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.h_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i.i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.i_i_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.i_i_c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.i_i_c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.i_i_c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.i_i_c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.i_i_c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.i_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_a_f.i_c_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_a_f.i_i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.i_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i.i_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.i_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.i_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.n_o_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_i.o_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m_c_i.p_i_z_d_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i.p_z_d_c_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i.p_z_d_t_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_i.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_i.t_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i.t_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_a_f.t_o_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_a_f.c_a_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_e.c_s_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_e.e_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_e.e_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_e.i_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_e.i_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_e.i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_e.i_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_e.l_m_i_f_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_e.m_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_e.o_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m_c_e.s_c_i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_e.t_i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_e.t_o_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_e.z_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.a_m_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.a_q_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.c_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.c_r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.f_s_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.m_e_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.m_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.u_c_q_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "n_p._r", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.a_D_E_D_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "n_p.a_D_E_D_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "n_p.a_D_E_D_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "n_p.a_D_E_D_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "n_p.a_D_E_D_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "n_p.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.a_i_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "n_p.a_N", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.a_p_n_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "n_p.a_p_n_6", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "n_p.a_p_n_9", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "n_p.a_S_D", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.a_s_d_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "n_p.A_G_o_T", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.A_G_w_1_w_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.A_G_w_2_w_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.A_D_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "n_p.A_D_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "n_p.A_D_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "n_p.A_D_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "n_p.A_D_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "n_p.C_E_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "n_p.C_E_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "n_p.C_E_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "n_p.C_E_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "n_p.C_E_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "n_p.C_S_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "n_p.C_S_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "n_p.C_S_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "n_p.C_S_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "n_p.C_S_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "n_p.C_T", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.C_W", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.D_o_A_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "n_p.D_o_A_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "n_p.D_o_A_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "n_p.D_o_A_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "n_p.D_o_A_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "n_p.d_n_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_day" + }, + { + "nullable": false, + "fieldPath": "n_p.d_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_day" + }, + { + "nullable": false, + "fieldPath": "n_p.G_D_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "n_p.G_D_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "n_p.G_D_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "n_p.G_D_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "n_p.G_D_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "n_p.I_A", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.L", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.L", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.m_n_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_month" + }, + { + "nullable": false, + "fieldPath": "n_p.N_E_D_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "n_p.N_E_D_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "n_p.N_E_D_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "n_p.N_E_D_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "n_p.N_E_D_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "n_p.N_E_D_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "n_p.N_E_D_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "n_p.N_E_D_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "n_p.N_E_D_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "n_p.N_E_D_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "n_p.N_S_D_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "n_p.N_S_D_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "n_p.N_S_D_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "n_p.N_S_D_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "n_p.N_S_D_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "n_p.N_w_n_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.P_N_3_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "n_p.P_N_3_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "n_p.P_N_6_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "n_p.P_N_6_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "n_p.P_N_9_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "n_p.P_N_9_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "n_p.P_N_9_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "n_p.P_N_9_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "n_p.P_N_9_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "n_p.r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.t_p_a_n_9", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.t_p_a_n_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.t_p_a_n_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.T_E", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.T_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.V", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.V_A", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.w_n_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_week" + }, + { + "nullable": false, + "fieldPath": "n_p.w_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_week" + }, + { + "nullable": false, + "fieldPath": "n_p.z_u_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.a_e", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.b", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.C_Q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.c_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.e_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.m_b", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.o_c_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.p_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.s_g", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_a_a.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_a_a.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_a_a.a_t_a_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "1_i_a_a.a_t_a_i_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "1_i_a_a.a_t_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "1_i_a_a.a_t_a_i_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "1_i_a_a.a_t_a_i_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "1_i_a_a.a_t_a_i_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "1_i_a_a.a_t_a_i_y_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "1_i_a_a.B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_e_q_d.b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_e_q_d.g_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_e_q_d.g_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_e_q_d.g_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_a_a.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_e_q_d.m_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "1_i_e_q_d.o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_e_q_d.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_e_q_d.q_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_e_q_d.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_e_q_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_a_a.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "1_i_a_a.u_l_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_a_a.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_a_a.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_a_a.a_t_a_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "2_s_a_a.a_t_a_i_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "2_s_a_a.a_t_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "2_s_a_a.a_t_a_i_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "2_s_a_a.a_t_a_i_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "2_s_a_a.a_t_a_i_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "2_s_a_a.a_t_a_i_y_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "2_s_a_a.B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_e_q_d.b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_e_q_d.g_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_e_q_d.g_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_e_q_d.g_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_a_a.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_e_q_d.m_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "2_s_e_q_d.o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_e_q_d.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_e_q_d.q_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_e_q_d.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_e_q_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_a_a.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "2_s_a_a.u_l_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_a_a.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_a_a.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_a_a.a_t_a_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "3_t_a_a.a_t_a_i_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "3_t_a_a.a_t_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "3_t_a_a.a_t_a_i_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "3_t_a_a.a_t_a_i_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "3_t_a_a.a_t_a_i_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "3_t_a_a.a_t_a_i_y_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "3_t_a_a.B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_e_q_d.b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_e_q_d.g_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_e_q_d.g_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_e_q_d.g_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_a_a.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_e_q_d.m_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "3_t_e_q_d.o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_e_q_d.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_e_q_d.q_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_e_q_d.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_e_q_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_a_a.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "3_t_a_a.u_l_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_a_a.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_a_a.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_a_a.a_t_a_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "4_f_a_a.a_t_a_i_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "4_f_a_a.a_t_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "4_f_a_a.a_t_a_i_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "4_f_a_a.a_t_a_i_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "4_f_a_a.a_t_a_i_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "4_f_a_a.a_t_a_i_y_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "4_f_a_a.B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_e_q_d.b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_e_q_d.g_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_e_q_d.g_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_e_q_d.g_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_a_a.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_e_q_d.m_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "4_f_e_q_d.o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_e_q_d.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_e_q_d.q_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_e_q_d.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_e_q_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_a_a.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "4_f_a_a.u_l_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_a_a.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_a_a.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_a_a.a_t_a_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "5_f_a_a.a_t_a_i_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "5_f_a_a.a_t_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "5_f_a_a.a_t_a_i_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "5_f_a_a.a_t_a_i_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "5_f_a_a.a_t_a_i_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "5_f_a_a.a_t_a_i_y_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "5_f_a_a.B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_e_q_d.b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_e_q_d.g_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_e_q_d.g_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_e_q_d.g_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_a_a.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_e_q_d.m_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "5_f_e_q_d.o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_e_q_d.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_e_q_d.q_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_e_q_d.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_e_q_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_a_a.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "5_f_a_a.u_l_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_a_a.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_a_a.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_a_a.a_t_a_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_a_a.a_t_a_i_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "f_a_a.a_t_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_a_a.a_t_a_i_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "f_a_a.a_t_a_i_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_a_a.a_t_a_i_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_a_a.a_t_a_i_y_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "f_a_a.B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_e_q_d.b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_e_q_d.g_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_e_q_d.g_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_e_q_d.g_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_a_a.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_e_q_d.m_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "f_e_q_d.o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_e_q_d.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_e_q_d.q_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_e_q_d.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_e_q_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_a_a.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_a_a.u_l_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_a_a.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_a_a.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_a_a.a_t_a_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "7_n_e_a_a.a_t_a_i_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "7_n_e_a_a.a_t_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "7_n_e_a_a.a_t_a_i_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "7_n_e_a_a.a_t_a_i_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "7_n_e_a_a.a_t_a_i_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "7_n_e_a_a.a_t_a_i_y_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "7_n_e_a_a.B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_q_d.b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_q_d.g_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_q_d.g_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_q_d.g_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_a_a.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_q_d.m_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "7_n_e_q_d.o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_q_d.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_q_d.q_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_q_d.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_q_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_a_a.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "7_n_e_a_a.u_l_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_a_a.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_a_a.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_a_a.a_t_a_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "8_n_e_a_a.a_t_a_i_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "8_n_e_a_a.a_t_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "8_n_e_a_a.a_t_a_i_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "8_n_e_a_a.a_t_a_i_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "8_n_e_a_a.a_t_a_i_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "8_n_e_a_a.a_t_a_i_y_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "8_n_e_a_a.B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_q_d.b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_q_d.g_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_q_d.g_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_q_d.g_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_a_a.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_q_d.m_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "8_n_e_q_d.o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_q_d.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_q_d.q_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_q_d.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_q_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_a_a.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "8_n_e_a_a.u_l_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "9_p_e_q_d.b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "9_p_e_q_d.g_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "9_p_e_q_d.g_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "9_p_e_q_d.g_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "9_p_e_q_d.m_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "9_p_e_q_d.o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "9_p_e_q_d.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "9_p_e_q_d.q_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "9_p_e_q_d.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "9_p_e_q_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "9_p_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "9_p_e_q_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.g_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.g_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.g_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.m_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.q_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d.B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d.a_t_a_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_a_d.a_t_a_i_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "a_a_d.a_t_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_a_d.a_t_a_i_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "a_a_d.a_t_a_i_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_a_d.a_t_a_i_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_a_d.a_t_a_i_y_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "a_a_d.B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_a_d.u_l_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_r_t.i_c_r_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_r_t.i_c_r_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_r_c.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_r_c.c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_r_c.c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_r_c.c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_r_c.c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_r_c.c_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_r_c.c_r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_r_c.r", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_r_c.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_r_c.x", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "f_c_l.a_c_w_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.a_f_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.a_l_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m.q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.d_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.d_a_f_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.d_a_l_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.h_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.h_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.l_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "f_c_l.m_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.q_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.q_c_w_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.q_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.q_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.q_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.q_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.q_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.q_w_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.r_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.s_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.s_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_l.s_o_a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.t_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.t_p_t_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.t_q_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_l.z_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_s_g.a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "c_o_c_s_i_f.c_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "i_s_g.i_v_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "i_s_g.i_v_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "i_s_g.i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_m_i_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_u_a_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "i_s_g.p_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "i_s_g.p_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.p_s_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_s_g.r_s_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_c_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_s_g.s_g_s_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_s_g.t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_o_c_s_i_f.t_i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_r_t.i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_r_t.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_s_d_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_i_v_q.i_v_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_i_v_q.i_v_q_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_i_v_q.t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_m_i.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_m_i.m_i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_m_i.t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.f_c_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.f_c_c_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.f_c_c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.f_c_c_r_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.f_c_c_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.f_c_c_r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.f_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.l_c_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.l_c_c_r_b_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.l_c_c_r_b_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.l_c_c_r_b_c_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.l_c_c_r_b_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.l_c_c_r_b_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.l_c_c_r_b_c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.l_c_c_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.l_c_c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.l_c_c_r_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.l_c_c_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.l_c_c_r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.l_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.f_c_i_b_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_r.t_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_e.b_r_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_e.c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_e.c_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_e.i_a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_e.i_e_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_e.i_e_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_e.i_e_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_m_e.i_e_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_m_e.i_e_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_e.i_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_e.i_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_e.i_s_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_m_e.i_s_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_m_e.i_s_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_e.m_g_c_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "c_m_e.m_g_v_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "c_m_e.m_m_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_e.m_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_e.s_e_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_e.s_e_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_e.s_e_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_m_e.s_e_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_m_e.s_e_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_e.s_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_e.s_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_e.s_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_e.s_s_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_m_e.s_s_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_m_e.s_s_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_e.s_s_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_i.a_d_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_i.c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_i.c_c_r_l_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_i.c_c_r_l_2", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_i.c_c_r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_i.d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_i.d_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_i.d_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_i.r_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_i.r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_i.c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_i.C_S_L", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_i.s_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "c_i.z_t_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.a_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.a_p_l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_m_d.a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "c_m_d.a_w_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_m_d.b_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.b_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_d.b_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "c_m_d.b_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_w_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_c_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_c_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_c_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_c_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_c_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_c_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_d.d_f_e_t_s_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_m_d.e_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.e_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.e_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.e_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.e_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_f_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_f_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_f_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_f_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_f_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_f_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_f_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_p_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_p_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_p_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_p_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_p_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_p_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_p_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_u_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_u_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_u_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_u_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_u_d_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_u_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_u_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_d.f_f_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.h_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.h_f_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.h_l_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.p_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.i_c_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "c_m_d.i_c_d_t_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "c_m_d.i_d_a_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "c_m_d.i_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_d_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_d_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_d_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_d_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_s_i_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_s_i_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_s_i_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_s_i_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_s_i_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_s_i_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_s_i_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_u_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_u_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_u_d_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_u_d_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_u_d_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_u_d_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_m_d.l_u_d_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_d.m_h_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.m_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_m_d.m_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_m_d.m_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.m_f_f_u_t_u", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_m_d.o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.p_f_o_b_f", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.p_p_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.r_a_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.r_b", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_m_d.r_b_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.s_o_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.s_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_d.s_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_m_d.s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "c_m_d.s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "c_m_d.s_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_m_d.s_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_d.t_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_m_d.t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_m_d.u_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.u_a_m_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_m_d.u_a_m_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_d.u_a_m_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_m_d.u_a_m_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "c_m_d.u_a_m_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "c_m_d.u_a_m_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_m_d.u_a_m_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_d.u_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_m_d.u_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_m_d.u_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "c_m_d.u_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "c_m_d.u_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_m_d.u_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_m_d.i_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "c_c_t.a_i_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "c_c_t.i_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.i_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "c_c_t.l_c_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "c_c_t.p_i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.q_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_a_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_a_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_a_u_l_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_q_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_q_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_q_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_q_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_q_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_q_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_q_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_q_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_f_q_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_f_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_i_a_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_i_a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_i_a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_i_a_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_i_a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_i_a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_i_q_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_i_q_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_i_q_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_i_q_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_i_q_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_i_q_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_i_q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_i_q_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_i_q_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t_i_q_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_f.c_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "c_f.e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_f.r_e_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date" + }, + { + "nullable": false, + "fieldPath": "c_f.t_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c._e_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c._e_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c._e_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c._e_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c._l_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c._l_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c._l_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c._l_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.a_m_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.a_m_n_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.a_m_p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.c_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.c_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.l_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.r_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.u_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "d_d_f.c_d_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_d_f.D_c_s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_d_f.D_c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_d_f.f_d_p_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "d_d_f.f_d_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_d_f.i_c_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "d_d_f.i_e_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "d_d_f.l_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "d_d_f.l_d_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_r_r.b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_z.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_z.c_e_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_e_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_z.c_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date" + }, + { + "nullable": false, + "fieldPath": "d_z.c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "d_r_r.c_d_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_z.d_f_r_l_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date" + }, + { + "nullable": false, + "fieldPath": "d_z.d_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_r_r.d_i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_z.d_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "d_r_r.i_a_e", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_r_r.i_a_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_r_r.i_a_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_z.i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_z.m_r_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_z.m_r_a_c_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_d_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "d_z.p_c_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_z.r_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_r_r.r_f", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "d_r_r.r_p_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_z.r_e", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_z.s_d_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_z.s_d_r_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "d_z.t_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_r_r.t_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "e.e", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "e.e_v_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "e.e_v_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "e.e_v_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "e.e_v_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "e.e_v_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "e.e_v_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "e.e_v_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "e.e_v_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "e.e_v_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "e.e_v_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "e.e_v_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "e.e_v_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "e.e_v_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "e.e_v_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "e.e_v_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "e.p_k", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "e.u_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "e.v", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "e.v_o", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_f.f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_s_f.h_c_c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_s_f.h_i_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_s_f.h_m_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_s_f.h_o_d_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_s_f.h_s_t_i_5_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_s_f.i_c_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_t_t.c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_t_t.c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_t_t.c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_t_t.c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_t_t.c_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_t_t.c_r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_t_t.f_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_t_t.r", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.b_c_f_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.c_p_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.c_p_r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.c_p_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.c_p_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.c_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.f_m_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.f_m_c_r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.i_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.i_t_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.i_n_m_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.i_n_p_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.i_p_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.i_p_c_r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.m_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.o_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.p_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.p_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.u_i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_c_r.l_i_c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_c_r.l_i_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_c_r.l_i_c_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_c_r.l_i_c_r_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_c_r.l_i_c_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_c_r.l_i_c_r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_c_r.l_i_e_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_c_r.t_i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.a_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.c_r_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_i_e.c_r_s_s_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_i_e.c_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.d_1_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.d_2_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_c_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_c_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_c_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_c_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_c_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_c_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_c_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.f_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.e_o_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_e.i_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_e.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_e.h_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.r_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_e.t_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_e.t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.a_l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.b", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.c_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.c_l_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.c_l_v", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.c_p_s_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.c_s_e", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.c_s_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.c_s_v", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.c_u_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.e", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.e_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.e_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.f_l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.i_m_p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.i_e_t_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.o_t_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_t.p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.r_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_t.r_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.s_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_t.s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.t_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_t.t_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_t.t_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_t.t_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_t.t_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.t_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_t.t_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_t.t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_t.t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_t.t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_t.t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_t.t_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_t.t_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.t_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_t.t_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_t.t_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_t.t_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_t.t_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.t_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_t.t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.u_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_t.u_t_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t._f_s_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_d_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_d_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_d_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_d_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_d_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_d_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_d_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_d_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_i_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_l_o_l_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_r_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_r_d_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_r_d_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_r_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_r_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_r_d_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_r_d_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_r_d_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_r_d_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_r_d_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_r_d_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_o_t_t_s_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_o_t_t_s_d_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_o_t_t_s_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_o_t_t_s_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_o_t_t_s_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_o_t_t_s_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_o_t_t_s_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_o_t_t_s_d_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_o_t_t_s_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_o_t_t_s_d_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_o_t_t_s_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_e_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_g", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_i_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_o_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_o_d_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_o_d_g", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_o_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_o_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_o_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_o_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_o_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_o_d_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_o_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_o_d_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_o_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_g", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_i_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_o_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_t_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_t_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_t_c_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_t_c_a_o_t_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_t_d_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_t_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_t_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_t_p_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_t_p_r_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_t_r_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_f_s_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_f_s_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_f_s_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_f_s_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_f_s_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_f_s_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_f_s_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_f_s_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_f_s_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_f_s_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_f_s_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_n_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_n_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_n_g", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_n_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_n_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_n_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_n_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_n_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_n_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_n_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_n_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_n_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_s_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_s_f_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_s_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.E_A_C_T_R_B_m_D_L", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_c_i_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_i_a_d_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_p_r_a_d_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_a_a_c_d_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_a_c_d_s_d_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_a_c_t_s_d_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_a_d_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_a_f_d_d_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_a_s_t_u_l_d_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.e_a_s_t_u_l_e_d_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_l_d_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_d_g", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_a_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_a_a_d_g", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_a_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_a_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_a_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_a_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_a_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_a_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_a_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_a_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_a_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_a_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.f_r_d_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.h_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.h_t_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.h_t_a_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "i_d_t.h_t_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.h_t_i_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "i_d_t.h_t_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.h_t_p_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "i_d_t.h_t_p_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.h_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i_d_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i_d_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i_d_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i_d_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i_d_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i_d_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i_d_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i_d_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i_d_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i_d_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i_d_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i_h_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_r_d_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.l_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.m_e_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.m_f_f_e_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.m_f_f_e_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.m_f_f_e_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.m_f_f_e_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.m_f_f_e_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.m_f_f_e_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.m_f_f_e_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.m_f_f_e_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.m_f_f_e_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.m_f_f_e_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.m_f_f_e_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.m_g_a_c_p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.m_g_c_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.m_z_p_u", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.m_t_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_minute" + }, + { + "nullable": false, + "fieldPath": "i_d_t.n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.o_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_m_f", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_n_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_n_a_d_g", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_n_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_n_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_n_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_n_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_n_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_n_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_n_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_n_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_n_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_n_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_d_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_d_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_d_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_d_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_d_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_d_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_d_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_d_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_d_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_d_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_d_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_e_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_e_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_e_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_e_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_e_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_e_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_e_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_e_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_e_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_e_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_e_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_e_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_c_l_d_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_d_a_g", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_i_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_i_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_i_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_i_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_i_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_i_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_i_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_i_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_i_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_i_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_i_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_i_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.p_r_a_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.R_B", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_v", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_d_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_d_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_d_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_d_a_g", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_d_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_d_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_d_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_d_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_d_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_d_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_d_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_d_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_d_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_b_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.t_t_a_i_h_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.t_t_a_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.u_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "i_d_t.u_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.u_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "i_d_t.u_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "i_d_t.u_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "i_d_t.u_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "i_d_t.u_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_d_t.u_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "i_d_t.u_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "i_d_t.u_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.u_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "i_d_t.u_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "i_d_t.v_f_r_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.a_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.a_c_r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.a_c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.a_c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.a_c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.a_c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.a_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.c_s_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.c_s_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.e_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.e_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c.e_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "l_c.e_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_c_i_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_c_i_c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_c_i_c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_c_i_c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_c_i_c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_c_i_c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_i_i_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_i_i_c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_i_i_c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_i_i_c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_i_i_c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_i_i_c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_o_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_o_c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_o_c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_o_c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_o_c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_o_c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_a_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.f_q_t_a_c_q_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.h_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.h_a_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.h_a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.h_a_l_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.h_a_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.h_a_w_l_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.h_b_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.h_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.h_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.h_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.h_s_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.h_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_a_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.i_a_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c_i_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c_i_c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c_i_c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c_i_c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c_i_c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c_i_c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_i_i_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_i_i_c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_i_i_c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_i_i_c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_i_i_c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_i_i_c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c_t_a_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c_r_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.l_c_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.l_c_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.m_c_w_3_d_o_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.m_d_a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.m_t_a_i_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "l_c.m_t_d_a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.o_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.o_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c.o_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "l_c.s_c_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.s_c_i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.v_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.v_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c.w_l_c_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.w_l_c_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.C_l_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.c_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.d_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.e_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.e_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "l_s_d.f_s_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.i_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_r_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_a_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_r_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_s_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "l_s_d.v_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.a_b_f_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_l_f.a_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_l_f.a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.a_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.a_d_p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.e_v", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.e_l_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_l_f.f_p_s_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date" + }, + { + "nullable": false, + "fieldPath": "l_l_f.f_i_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.i_a_e", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_l_f.i_c_r_e", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_l_f.i_f_l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_l_f.i_f_l_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_o_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_o_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_o_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_o_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_o_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_o_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_o_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_o_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_o_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_o_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_o_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_o_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_o_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_o_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_o_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_p_o_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_p_o_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_p_o_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_p_o_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_p_o_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_p_o_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_p_o_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_p_o_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_p_o_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_p_o_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_p_o_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_p_o_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_p_o_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_p_o_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_p_o_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_p_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_l_f.t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.m_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.p_o_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_l_f.p_o_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.p_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.p_s_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.p_s_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.r_i_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_i_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_l_f.t_o", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.t_o_b", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.t_p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.u_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.a_s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_m_i_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_v_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.g_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.l_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.o_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.u_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.C_R_A_I", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.C_R_A_T_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.C_R_A_T_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.C_R_A_T_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.C_R_A_T_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.C_R_A_T_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.C_R_A_T_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.C_R_A_T_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.C_R_A_T_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.C_R_A_T_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.C_R_A_T_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.C_R_A_T_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.C_R_A_T_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.C_R_C", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.C_R_I", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.T_I", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_second" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_j_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "l_c_s.c_p_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_s.c_s_s", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_s.c_s_w_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c_s.c_s_w_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c_s.c_s_w_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c_s.m_a_C", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c_s.m_g_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c_s.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_s.n_o_a_m_s_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.n_o_a_m_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.n_o_h_m_s_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.n_o_h_m_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.n_o_m_m_s_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.n_o_m_m_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.n_o_m_m_w_s_a_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.n_o_m_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_s.r_o_p_w_e_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_e_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_i_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_i_i_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_second" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_s_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_w_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_w_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c_s.t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.t_s_i_i_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.t_s_i_q_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.t_s_i_w_u_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.t_m_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "l_c_s.t_t_a_s_w_f_m_r_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.t_t_m_s_w_f_a_r_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_u_i_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_m.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.a_s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.c_m_i_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_m.c_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.c_v_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m.c_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_m.c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.g_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m.l_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_m.m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.o_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_m.o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_m.p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_m.p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m.u_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a_t_a_c_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a_t_a_c_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a_t_a_c_y_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a_t_a_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a_t_a_i_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a_t_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a_t_a_i_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a_t_a_i_m_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a_t_a_i_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a_t_a_i_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a_t_a_i_y_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a_t_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_m_u.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_m.a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_m_u.B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_m.c_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.c_r_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m_u.d_g_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_m.i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_l_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_m.l_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m_u.l_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_m.m_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_m.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_m.m_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m_u.o_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m_u.r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m_u.r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_m_u.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m_u.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m_u.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_m.t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m_u.t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m_u.t_z", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_l_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m_u.v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_m_u.z_u_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.a_a_i_c_w_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.a_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.c_b_v_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.c_f_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.C_R_l_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.C_R_l_2", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.C_R_l_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.C_R_l_4", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.c_t_e_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.d_f_c_s_t_n_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.d_f_l_s_t_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.d_c_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "m_b_s.d_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.d_s_t_o_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.f_i_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_b_s.f_i_o_s_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.f_m_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.f_m_i_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_b_s.f_m_i_i_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_b_s.f_m_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.f_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.f_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.f_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.f_v_r_d_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.f_v_r_d_t_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_b_s.i_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_b_s.i_d_t_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_b_s.i_f_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_b_s.i_i_t_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_b_s.i_m_p_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_b_s.i_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_b_s.L_m_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.l_s_g_o_d_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_b_s.l_s_g_s_d_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_b_s.l_d_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.m_c_r_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.m_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.N_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.n_s_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m_b_s.n_s_s_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "m_b_s.n_s_s_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "m_b_s.n_s_s_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "m_b_s.n_s_s_e_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.n_s_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m_b_s.n_s_s_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m_b_s.n_s_s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_b_s.n_s_s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m_b_s.n_s_s_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "m_b_s.n_s_s_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m_b_s.n_s_s_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m_b_s.q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.r_s_f_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.r_s_f_m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_e_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_e_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_e_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_e_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_e_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_e_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_e_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_e_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_e_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_e_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_e_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_e_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_e_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_e_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_f_e_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_f_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_f_i_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_f_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_f_i_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_f_m_e_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_f_m_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_f_m_i_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_f_m_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_f_m_i_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.M_N_P", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_s_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_s_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_s_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_s_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_s_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_s_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_s_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_s_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_s_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_s_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_u_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.t_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "m_b_s.t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_b_s.t_r_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.a_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.a_p_l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m.a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "m.a_w_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m.c_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m.c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m.c_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m.c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m.c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m.c_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m.c_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m.c_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.c_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m.c_c_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "m.c_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m.c_c_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "m.c_c_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m.c_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m.c_c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m.c_c_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m.c_c_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "m.c_c_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m.c_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m.c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m.c_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m.c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m.c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m.c_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m.c_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m.d_f_e_t_s_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m.e_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m.e_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.e_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date" + }, + { + "nullable": false, + "fieldPath": "m.e_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m.e_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m.f_f_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m.f_f_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m.f_f_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m.f_f_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m.f_f_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m.f_f_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m.f_f_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m.f_p_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m.f_p_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m.f_p_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m.f_p_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m.f_p_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m.f_p_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m.f_p_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m.f_u_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m.f_u_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m.f_u_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m.f_u_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m.f_u_d_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m.f_u_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m.f_u_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m.f_f_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.h_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.h_f_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.h_l_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.p_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.i_c_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m.i_c_d_t_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m.i_d_a_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m.i_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m.l_d_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m.l_d_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m.l_d_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.l_d_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.l_u_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m.l_u_d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m.l_u_d_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m.l_u_d_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m.l_u_d_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m.l_u_d_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m.l_u_d_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m.m_h_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.m_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m.m_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m.m_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.m_f_f_u_t_u", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m.o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.p_f_o_b_f", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.p_p_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.r_a_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.r_b", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m.s_o_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m.s_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m.s_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m.s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m.s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m.s_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m.s_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m.t_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m.t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m.u_a_m_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m.u_a_m_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m.u_a_m_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m.u_a_m_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m.u_a_m_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m.u_a_m_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m.u_a_m_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m.i_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "d_u.a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_u.d_o_b_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "d_u.d_c_t_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "d_u.d_u_t_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "d_u.e_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_u.e_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_u.e_f", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_u.e_s_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "d_u.e_i_t_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "d_u.f_n_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_u.l_n_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_u.p_f", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_u.p_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_u.p_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_u.r_b", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "d_u.r_b_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_u.s_o_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_u.u_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "d_u.u_i_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_u.u_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "d_u.u", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.A_M_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_h_o_p_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_m_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_m_b_a_e_v", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_m_b_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_o_m_b", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_p_f_p_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_p_m_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_p_m_d_i_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_p_m_b_p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_p_m_b_p_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_p_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_p_p_h_f_p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_p_p_h_n_p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_p_p_i_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_p_v", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_r_b_a_e_v", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_r_b_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_r_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_r_p_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_s_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_v_g_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_h_o_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_o_i_m_m_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_d_1_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_d_2_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_d_2_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_d_2_m_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_c_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_d_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_f_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_q_o_l_i_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.B_m_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.c_d_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_c.c_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.c_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.C_M_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.c_f_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.C_R_l_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.C_R_l_2", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.C_R_l_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.C_R_l_4", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.D_M_M_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.d_t_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.E_I_P_M_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.e_a_c_v", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.e_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.F_M_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.F_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.F_P_S", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.h_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.i_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.i_n_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.i_c_e_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.i_c_s_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.i_c_w_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.i_c_i_v", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.i_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.L_M_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.L_M_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.m_i_p_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.m_c_r_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_c.m_i_i_z", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.m_d_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_c.n_o_e_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_c.P_L_M_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.P_F_M_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.R_M_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.R_M_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.S_E", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.S_I", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.S_V", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.S_A_M_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.s_s_f_w_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.s_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.S_M_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.T_R_M_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_c.T_M_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_o", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_a_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_m_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_m_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_m_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_m_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_m_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_m_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_m_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_m_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_m_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_m_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_m_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_c_r_m_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_e_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_e_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_e_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_e_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_e_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_e_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_e_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_e_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_e_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_e_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_e_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_e_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_s_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_s_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_s_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_s_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_s_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_s_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_s_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_s_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_s_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_s_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_s_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_i_s_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m_i_c.v_i_f_a_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_i_c.W_A_M_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.z_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_i_c.c_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "o_m_s.b_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "o_m_s.c_m_l_9_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "o_m_s.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "o_m_s.s_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "o_m_s.t_c_l_9_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "o_m_s.t_r_l_9_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "o_m_s.u_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "q_n_n.n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "q_n_n.n_i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "q_n_n.n_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "q_n_n.z_t_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_p_d.a_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_p_d.d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_p_d.d_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_p_d.d_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_p_d.d_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_p_d.d_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_p_d.d_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_p_d.d_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_p_d.d_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_p_d.d_h_p_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_p_d.m_d", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date" + }, + { + "nullable": false, + "fieldPath": "s_p_d.n_a_p_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_C_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_C_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_C_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_C_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_C_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_C_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_C_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_C_2", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_C_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_C_4", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_C_5", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_C_6", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_C_7", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_C_8", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_C_9", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_D_2", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_D_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_D_4", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_D_5", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_D_6", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_D_7", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_D_8", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_D_9", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_D_2", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_D_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_D_4", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_D_5", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_D_6", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_D_7", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_D_8", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_D_9", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_I_2", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_I_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_I_4", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_I_5", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_I_6", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_I_7", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_I_8", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_I_9", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_D_2", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_D_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_D_4", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_D_5", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_D_6", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_D_7", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_D_8", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_D_9", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_I_2", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_I_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_I_4", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_I_5", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_I_6", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_I_7", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_I_8", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_F_V_I_9", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_I_2", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_I_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_I_4", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_I_5", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_I_6", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_I_7", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_I_8", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_I_9", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_S_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_S_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_S_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_S_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_S_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_S_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_S_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_S_2", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_S_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_S_4", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_S_5", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_S_6", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_S_7", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_S_8", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_S_9", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_T_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_T_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_T_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_T_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_T_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_T_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_T_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_T_2", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_T_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_T_4", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_T_5", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_T_6", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_T_7", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_T_8", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.A_T_9", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.A", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.c_d_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.d_c_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date" + }, + { + "nullable": false, + "fieldPath": "p_e.I", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.E_I", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.e_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "p_e.E_d_c_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "p_e.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e.l_o_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.m_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e.p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e.p_v_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_D_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_D_2", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_D_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_D_4", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_D_5", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_D_6", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_D_7", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_D_8", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_D_9", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_I_2", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_I_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_I_4", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_I_5", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_I_6", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_I_7", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_I_8", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_I_9", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_M_S_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_M_S_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_M_S_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_M_S_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_M_S_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_M_S_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_M_S_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_M_S_2", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_M_S_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_M_S_4", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_M_S_5", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_M_S_6", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_M_S_7", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_M_S_8", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.Q_M_S_9", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e.r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.R", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.S_A_B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.S_F", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.S_I", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.S_M_S", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.S_N", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e_s.S_P", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.S_S", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e_s.S_P", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e.s_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.w_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.s_I_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.s_I_2", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.s_I_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.s_I_4", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.s_I_5", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.S", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.t_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_e.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_s.c_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_s.m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_s.m_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_s.n_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_s.n_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_s.p_p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_s.p_s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_s.r_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_s.s_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_s.t_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_s.t_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_s.t_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "o_s._f_s_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "o_s.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "o_s.a_r_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.e_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.e_q_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.e_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.f_r_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.i_f_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.i_i_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_second" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.q_e_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_c_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "o_s.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "o_s.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "o_s.h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_s.i_s_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "o_s.i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "o_s.l_o_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "o_s.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_s.m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "o_s.s_r_m_", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_s.s_r_s_", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_s.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "o_s.t_t_f_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_s.w_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_s.w_t_s_w_s_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_s.w_t_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "o_s.w_t_t_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "o_s.w_t_t_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "o_s.w_r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_s.y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.a_a_i_c_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.a_a_i_c_w_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.b_m_2_e_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.b_s_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.b_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.c_b_v_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.r_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.r_l_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.c_e_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.d_f_a_c_t_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.d_f_l_d_d_t_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.d_f_l_r_d_d_t_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.d_c_2_0_2_e_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.e_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_e.e_c_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_e.e_c_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_e.e_c_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_e.e_c_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_e.e_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_e.e_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_e.e_c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_e.e_c_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_e.e_c_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_e.e_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.f_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.h_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.I_D_T_A_O_C", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.m_i_p_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.i_h_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_e.i_d_t_a_o_c_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_e_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.l_d_d_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.l_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_e.l_r_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_e.l_s_d_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_e.l_c_e_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.m_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.m_f_a_c_t_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.N_P", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.p_e_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.r_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.r_i_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.r_t_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.s_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.s_i_m_e_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_e.w_n_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_e.w_v_n_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_e.w_f_a_c_t_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.y_f_a_c_t_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a._e_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a._f_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a._l_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_c_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_a_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.g_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.i_g_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.k", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_a_g_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_v_f.n_s_o_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_a_a.p_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_v_f.s_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_a_a.s_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.e_i_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_v_f.t_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_v_f.v_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_v_f.v_a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_f_l.a_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_f_l.d_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.f_p_u", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.f_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.g", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.g_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.r_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.s_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.t_p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_f_l.u_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_l.g_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_l.l_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_l.l_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_p.g_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_p.p_f_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_p.p_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_g._e_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_g._f_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_g._l_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_g.c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_g.c_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_g.c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_g.d_s_l_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_g.d_s_l_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_g.d_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_n_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_g.g_c_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_g.g_d_l_b_5_a_1_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_g.g_l_v_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_g.g_p_u", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_g.g_s_h_a_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_g.g_t_i_3_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_g.g_t_l_b_2_a_8_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_g.g_u_i_l_9_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_g.g_v_i_l_9_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_g.i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_g.s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_g.t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_g.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_g.t_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_g.u_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_d_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_d_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_d_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_d_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_d_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_d_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_d_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_u_a.c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_u_a.c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_u_a.c_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_u_a.i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u_a.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_u_a.u_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u_a.u_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_u._e_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_u._f_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_u._l_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_u.a_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_u.a_e_s_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u.a_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u.a_l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u.a_l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_u.a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u.a_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_d.b", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u.c_b_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_u.c_b_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_a_d.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_d.c_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_d.c_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_d.c_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_u.c_a_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_u.c_p_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u.e", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u.e", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u.g_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_u.i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u.i_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_u.i_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_a_d.l_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_d.l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_d.l_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_d.m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_d.m_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_u.n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u.p_t_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u.p_a_u", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u.p_f_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u.p_l_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u.r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_d.r_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_u.s_i_c_b_e", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_d.s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_d.t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_d.t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date" + }, + { + "nullable": false, + "fieldPath": "s_a_d.t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_d.t_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.b_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.h_a_g_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_second" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_c.c_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_c.p_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_c.s_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_c.s_a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_c.t_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_c.t_n_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_c.t_c_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_c.t_s_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_c.t_f_s_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_c.w_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_t_a_c_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_t_a_c_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_t_a_c_y_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_t_a_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_t_a_i_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_t_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_t_a_i_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_t_a_i_m_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_t_a_i_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_t_a_i_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_t_a_i_y_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_t_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c_r_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.d_g_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_l_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.l_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.o_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_a.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.t_z", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_l_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_a.z_u_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_q.b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_a_q.d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_q.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_a_q.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_q.g_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_q.g_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_q.g_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_a_q.m_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_a_q.o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_q.q_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_q.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_q.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_q.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_a_q.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.C_l_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.c_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.d_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.e_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.e_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.f_s_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.i_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_r_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_a_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_r_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_s_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.v_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.a_b_f_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_a_s_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_h_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_h_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_t_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_w_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_o", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.e_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.e_q_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.f_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "f_t_o_q.f_t_o_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.f_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.f_a_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.f_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.f_a_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.f_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.f_a_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.f_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.f_s_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.f_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.f_a_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_t_o_q.i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.i_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.l_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.l_s_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.m_c_q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_a_a_t_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_e_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_e_q_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_e_q_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_e_q_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_e_q_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_e_q_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_e_q_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_e_q_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.n_u", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_a_a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_e_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_e_q_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_q_e_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.q_e_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.q_e_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.q_e_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.q_e_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.q_e_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.q_e_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.q_e_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.q_e_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.q_h_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_a_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_e_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_a_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_t_a_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_t_q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.u_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_u_s_t_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.a_h_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_c_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_c_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_c_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_c_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_c_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_c_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_second" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_c_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_c_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_c_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_r_b_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_r_b_r_a_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.i_n_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.p_c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.s_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.z_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_f_p_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_c_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_c_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_c_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_c_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_c_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_c_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_c_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.b_p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.b_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_n_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_s_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_d_t_f_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_d_t_f_s_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_f_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_i_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_r_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_r_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_r_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_r_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_r_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_r_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_r_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_t_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_t_a_l_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_c_1", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_c_2", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_i_p_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_i_c_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.e_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_d_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_d_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_q_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_c_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_c_r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_r_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.g_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.h_t_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.h_t_a_l_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_q_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_w_3_d_o_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_w_3_d_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_c_f_i_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.i_w_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_a_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_i_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_s_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.m_d_a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.m_h_d_i_l_3_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.m_t_a_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.m_t_a_i_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.m_t_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.m_t_a_i_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.m_t_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.m_f_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.m_t_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.m_t_a_l_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.n_o_b_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.o_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.o_f_l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.p_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.p_c_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.r_r_i_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.r_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.r_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.r_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.r_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_t_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_second" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_t_a_l_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_second" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_i_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_c_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_c_d_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_c_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_c_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_c_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_c_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_c_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_c_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_n_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_n_d_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_n_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_n_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_n_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_n_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_n_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_n_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_s_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_s_d_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_s_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_s_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_s_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_s_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_s_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_s_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_p_d_n_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_c_d_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_f_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_a_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_t_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_t_s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_t_s_w_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_t_s_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.u_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.v_l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.w_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.t_i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.t_t_s_l_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.t_t_s_w_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_d_o_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_d_o_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_d_o_w_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_d_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_h", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_h_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_m_n", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_q", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_q_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_t_o_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_w_o_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_y", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.u_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "t_a_d.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "t_a_d.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "t_a_d.B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "t_a_d.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "t_a_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u_a.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u_a.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.a_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.a_w_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u_a.B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.c_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.c_d_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.d_c_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.e_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.e_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.e_g_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "p_u.e_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "p_u.e_l_u_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "p_u.e_m_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.e_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "p_u.e_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.e_q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.e_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "p_u.e_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "p_u.e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.i_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.l_o_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u_a.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.m_s_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "p_u.p_v_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.q_m_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.q_w_m_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.s_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.s_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.s_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.s_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.s_m_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.s_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.s_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "p_u.s_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.s_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.s_w_m_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.s_w_p_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.s_w_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u_a.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.t_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "p_u.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_d.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_d.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_d.B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_d.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "a_d.u_l_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "u_c_c_r_m.c_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "u_c_c_r_m.c_r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "u_c_c_r_m.f_s_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "u_c_c_r_m.m_e_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date" + }, + { + "nullable": false, + "fieldPath": "u_c_c_r_m.m_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date" + }, + { + "nullable": false, + "fieldPath": "u_c_c_r_m.u_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "u_c_c_r_m.q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_c_w_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_f_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_l_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_z_a.a_t_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "c_z_a.a_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_z_a.B", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_m_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_s_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.h_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.h_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.i_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.i_s_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "c_z_a.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.p_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.p_k", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.q_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.q_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.q_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.q_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.q_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.q_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.q_w_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.s_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.s_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.s_g_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.s_g_o_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.s_o_a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.s_d_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.t_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_z_a.u_l_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.z_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_z_a.z_u_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f.e_t_t_l_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f.e_z_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f.h_v_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f.l_c_t_f_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f.o_t_a_i_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f.s_a_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f.t_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_g_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.f_f", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_g_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.i_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_second" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_P_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_second" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_u_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.n_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_second" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_u_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.p_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.q_e_a_i_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_second" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_P_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_second" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.q_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.s_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.u_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.w_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.w_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.w_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.z_f_m_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t.a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.a_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.a_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.a_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.a_f_p_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.a_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.a_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.a_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t.a_c_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t.a_c_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.a_c_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.a_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "z_t.a_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t.a_c_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t.a_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t.a_c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t.a_c_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t.a_c_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.a_c_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t.a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.b_p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.b_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_n_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_s_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t.c_d_t_f_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.c_d_t_f_s_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_f_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_i_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.c_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t.c_r_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.d_r_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t.d_r_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t.d_r_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.d_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "z_t.d_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t.d_r_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t.d_r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t.d_r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t.d_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t.d_r_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.d_r_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t.d_t_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_day" + }, + { + "nullable": false, + "fieldPath": "z_t.d_t_a_l_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_day" + }, + { + "nullable": false, + "fieldPath": "z_t.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.d_c_1", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.d_c_2", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.d_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.d_i_p_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.d_i_c_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.d_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.d_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t_d_d.d_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t_d_d.d_d_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t_d_d.d_d_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t_d_d.d_d_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t_d_d.d_d_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_d_d.d_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t_d_d.d_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t_d_d.d_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t_d_d.d_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t_d_d.d_d_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_d_d.d_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t_d_d.d_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t_d_d.d_d_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t_d_d.d_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t.e_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.f_d_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_d_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t.f_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.f_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.f_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.f_q_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t.f_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.f_c_r_1_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.f_c_r_2_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.f_c_r_3_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.f_c_r_4_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.f_c_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.f_c_r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.f_r_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.g_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.h_t_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.h_t_a_l_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_hour" + }, + { + "nullable": false, + "fieldPath": "i_t.a_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.i_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.i_q_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t.i_w_3_d_o_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t.i_w_3_d_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t.i_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t.i_c_f_i_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t.i_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t.i_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t.i_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t.i_w_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t.l_a_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.l_i_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.l_s_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.l_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t.l_l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.m_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.m_t_a_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.m_t_a_i_d_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "z_t.m_t_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.m_t_a_i_m_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "z_t.m_t_t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.m_f_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t.m_t_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_minute" + }, + { + "nullable": false, + "fieldPath": "z_t.m_t_a_l_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_minute" + }, + { + "nullable": false, + "fieldPath": "z_t.n_o_b_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.o_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.o_f_l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.p_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.p_c_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.r_r_i_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.r_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.r_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.r_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.r_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.s_t_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_second" + }, + { + "nullable": false, + "fieldPath": "z_t.s_t_a_l_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "duration_second" + }, + { + "nullable": false, + "fieldPath": "z_t.s_i_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_f_s_u_2.s_u_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_c_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_c_d_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_c_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_c_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_c_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_c_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_c_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_c_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_n_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_n_d_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_n_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_n_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_n_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_n_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_n_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_n_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_s_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_s_d_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_s_d_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_s_d_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_s_d_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_s_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_s_d_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_s_d_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.s_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.t_p_d_n_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.t_c_d_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.t_f_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.t_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t_d_d.t_i", + "description": "", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.t_a_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.t_t_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.t_t_s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.t_t_s_w_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.t_t_s_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NullType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute30" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_t.u_a_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_t.v_l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_t.w_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_r_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_t_t_f_r_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_t_t_r_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.b_w_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.b_w_t_h_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.b_w_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.b_w_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.f_t_t_r_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_i", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_i_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.q_b_t_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.q_b_t_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.q_b_w_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.r_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_e_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_r_q_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_s_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_s_q_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_s_q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_s_q_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_e_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_r_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_date" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_d_o_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_month" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_d_o_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_d_o_w_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_week_index" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_d_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_day_of_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_h_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_hour_of_day" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_minute" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_name" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_m_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_month_num" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_q_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "date_quarter_of_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_t_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_time_of_day" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_w_o_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "date_week_of_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_s_t_y", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + }, + { + "tag": "urn:li:tag:Temporal" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.DateType": {} + } + }, + "recursive": false, + "nativeDataType": "date_year" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.t_i", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.t_t_f_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.t_t_f_r_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.t_t_f_r_h_b", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.t_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.t_t_r_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.i_t_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.t_t_r_m_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.EnumType": {} + } + }, + "recursive": false, + "nativeDataType": "tier" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.t_t_s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.t_t_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.t_t_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.t_t_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.w_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.w_t_s_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "s_n.d_t_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_n.d_t_b_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_n.d_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_n.d_t_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_n.d_t_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_n.d_t_u_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_n.f_o_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_n.p_t_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_n.p_t_b_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_n.p_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_n.p_t_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_n.p_t_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_n.p_t_u_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_n.p_t_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_n.p_t_b_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_n.p_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_n.p_t_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_n.p_t_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "s_n.p_t_u_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_n.r_n_u", + "description": " ", + "isPartOfKey": true, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Dimension" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.a_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.a_c_p_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.a_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.a_m_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.b_e_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "b_h.b_h_i_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.b_s_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.c_w_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.c_w_t_r_f_q_t_a_c_q_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.c_w_t_r_f_q_t_a_c_q_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.d_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_q_t_a_c_q_m_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.f_q_t_a_c_q_m_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c_t_a_c_m_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c_r_i_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_i_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.i_c_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_h.i_h_i_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.m_c_w_3_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.p_c_l_t_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.q_r_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_a_r_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_b_s_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_c_w_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_c_w_t_n_f_q_t_a_c_q_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_c_s_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_e_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_f_q_t_a_c_q_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_f_q_t_a_c_q_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_f_q_t_a_c_q_m_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_i_c_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_i_i_c_r_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_i_i_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_i_a_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_i_c_t_a_c_m_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_l_c_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_v_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i_c.t_w_l_c_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i.c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_i.i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_e.e_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.a_q_m_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.a_q_m_r_n_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.a_q_m_r_f_c_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.a_q_m_r_f_c_r_m_a_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.a_q_m_r_f_c_r_a_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.a_q_m_r_f_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.a_q_m_r_f_s_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.a_q_m_r_u_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.c_q_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.c_r_m_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.c_r_m_r_u_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.c_r_m_r_u_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.c_r_m_r_u_c_n_s_m_o_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.k_q_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.o_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.p_r_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.q_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.s_m_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.q_t_f_o_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.q_t_f_c_r_m_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.q_t_f_c_r_a_o_m_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.q_t_f_c_r_a_s_m_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.q_t_f_s_m_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.u_q_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.u_c_f_u_r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.u_c_r_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.u_c_a_q_r_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_b_v_m.u_c_a_q_r_a_f_s_m_o_o_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.A_N_D_A", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average_distinct" + }, + { + "nullable": false, + "fieldPath": "n_p.A_Q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average_distinct" + }, + { + "nullable": false, + "fieldPath": "n_p.A_n_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average_distinct" + }, + { + "nullable": false, + "fieldPath": "n_p.a_t_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average_distinct" + }, + { + "nullable": false, + "fieldPath": "n_p.a_t_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average_distinct" + }, + { + "nullable": false, + "fieldPath": "n_p.P_A_G_o_T", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.P_A_G_w_1_w_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.P_A_G_w_2_w_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.P_G_G_o_T", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.P_G_G_w_1_w_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.P_G_G_w_2_w_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.P_I_A", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.P_T_A", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.P_T_G", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.P_T_I", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.P_V_A", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "n_p.t_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "n_p.t_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.t_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum_distinct" + }, + { + "nullable": false, + "fieldPath": "n_p.t_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "n_p.t_i_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum_distinct" + }, + { + "nullable": false, + "fieldPath": "n_p.t_r_1_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum_distinct" + }, + { + "nullable": false, + "fieldPath": "n_p.t_r_2_w", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum_distinct" + }, + { + "nullable": false, + "fieldPath": "n_p.t_v_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum_distinct" + }, + { + "nullable": false, + "fieldPath": "n_p.t_o_t_g", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum_distinct" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.e_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.e_r_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.p_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.p_r_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.r_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_r_w_c.t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "7_n_e_a_a.s_p_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "a_a_d_g_d.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count" + }, + { + "nullable": false, + "fieldPath": "c_r_c.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "f_c_l.a_a_c_w_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "f_c_l.a_a_c_w_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "f_c_l.a_h_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "f_c_l.a_h_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "f_c_l.a_h_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "f_c_l.a_h_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "f_c_l.a_t_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "f_c_l.a_t_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "f_c_l.c_v", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "f_c_l.d_c_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "f_c_l.i_d_c_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "f_c_l.t_h_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "f_c_l.w_t_i_q_7_p_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "f_c_l.w_t_i_q_8_p_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "f_c_l.w_t_i_q_9_p_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "f_c_l.w_t_i_q_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "f_c_l.w_t_i_q_m_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "i_s_g.a_p_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.a_p_i_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.a_p_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.a_p_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.a_m_s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "i_s_g.i_v_a_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.i_v_a_i_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.i_v_a_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.i_v_a_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.i_v_c_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.i_v_c_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.i_v_c_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.i_v_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_f_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_f_i_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_f_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_f_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_m_i_r_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_m_i_r_i_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_m_i_r_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_m_i_r_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_u_a_l_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_u_a_l_i_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_u_a_l_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.m_u_a_l_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.p_c_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.p_c_i_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.p_c_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.p_c_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.p_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.p_p_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.p_p_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_s_g.p_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_s_g.t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "c_r_t.i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "c_r_t.m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "c_r_t.t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "c_c_r.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count" + }, + { + "nullable": false, + "fieldPath": "c_m_e.t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "c_i.c_t_i", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "c_m_d.a_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average_distinct" + }, + { + "nullable": false, + "fieldPath": "c_m_d.b_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_i_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_i_t_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_m_d.c_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "c_m_d.e_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_m_d.m_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "median" + }, + { + "nullable": false, + "fieldPath": "c_m_d.m_s_l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "median" + }, + { + "nullable": false, + "fieldPath": "c_m_d.m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "c_m_d.p_u_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_m_d.r_b_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_m_d.s_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_m_d.s_i_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_c_t.a_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_a_i_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "c_c_t.t_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "c_f.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.e_p_m_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.h_r_m_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.m_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.s_l_m_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "o_c_s_c.s_b_m_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "d_z.d_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "d_r_r.d_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "d_r_r.r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "d_r_r.r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "d_z.t_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "e.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "e.u_u", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_s_f.c_c_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_s_f.c_c_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_f.d_q_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_s_f.d_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_f.f_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_s_f.f_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_f.i_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_s_f.i_a_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_s_f.i_a_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_f.m_e_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_s_f.m_e_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_f.s_t_i_5_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_s_f.s_t_i_5_d_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_t_t.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.a_p_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.c_a_p_u_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.c_f_p_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.c_p_u_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.f_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.f_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.f_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.i_A", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.i_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.m_p_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.n_t_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.n_p_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.p_a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.p_p_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.t_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_c_b_p.t_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_c_r.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count" + }, + { + "nullable": false, + "fieldPath": "m_i_e.c_w_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_i_e.i_a_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_i_e.i_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_i_e.i_e_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_i_e.m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_i_e.t_i_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "m_i_e.t_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.TimeType": {} + } + }, + "recursive": false, + "nativeDataType": "date_raw" + }, + { + "nullable": false, + "fieldPath": "i_t.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_d_t_c_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_d_t_i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_r_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_t_t_a_i_h_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_t_t_a_i_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "i_d_t.a_t_t_a_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "i_d_t.C_i_2_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_d_t.C_i_2_d_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c_w_2_p_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_d_t.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_d_t.d_c_e_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i_d_i_2_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_d_t.i_d_i_2_d_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "i_d_t.o_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_d_t.r_p_t_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_d_t.s_d_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "i_d_t.u_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.a_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.a_c_p_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.a_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "l_c.a_m_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "l_c.b_e_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.b_s_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.c_w_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.c_w_t_r_f_q_t_a_c_q_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.c_w_t_r_f_q_t_a_c_q_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.d_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.f_q_t_a_c_q_m_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.f_q_t_a_c_q_m_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c_t_a_c_m_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c_r_i_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.i_i_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.i_c_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.m_c_w_3_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.p_c_l_t_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.q_r_a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c.t_a_r_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_b_s_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_c_w_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_c_w_t_n_f_q_t_a_c_q_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_c_s_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_e_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_f_q_t_a_c_q_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_f_q_t_a_c_q_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_f_q_t_a_c_q_m_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_i_c_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_i_i_c_r_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_i_i_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_i_a_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_i_c_t_a_c_m_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "l_c.t_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_l_c_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_v_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c.t_w_l_c_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.a_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.a_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.a_a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.a_a_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.a_a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.a_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "l_s_d.a_e_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "l_s_d.c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.c_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.C_c_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.C_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.C_c_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.C_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.C_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.C_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.e_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.e_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.e_a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.e_a_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.e_a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.i_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.i_c_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.i_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.i_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.i_c_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.i_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.l_c_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.l_c_a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.l_c_a_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.l_c_a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.p_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.p_a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.p_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.p_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_c_c_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_c_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_c_c_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_c_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_c_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_c_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.S_r_g", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.t_s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.t_s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.v_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.v_a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.v_a_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_s_d.v_a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_s_d.s_g", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.a_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "l_l_f.a_p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "l_l_f.d_o", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_f", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_p_o", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.l_c_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_l_f.r_i_r_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "l_l_f.t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "l_l_f.t_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "l_l_f.t_d_p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "l_l_f.t_o_e", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "l_l_f.t_p_e", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "l_l_f.t_p_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "l_l_f.t_p_s_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "l_l_f.t_p_s_d_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "l_l_f.u_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_l_f.w_a_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_m_d.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.c_r_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c_c_r.d_c_r_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_l_c_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_h_t_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_h_t_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_t_a_s_w_f_m_r_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_t_m_s_w_f_a_r_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_t_s_i_w_u_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "l_c_s.a_w_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.c_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.h_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.h_p_a_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.i_s_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.l_c_a_r_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.n_a_c_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "l_c_s.r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_a_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_n_o_a_m_s_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_n_o_a_m_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_n_o_h_m_s_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_n_o_h_m_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_n_o_m_m_s_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_n_o_m_m_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_n_o_m_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_t_t_a_s_w_f_m_r_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.s_t_t_m_s_w_f_a_r_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.t_s_i_w_u_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "l_c_s.t_n_o_m_m_w_s_a_a_j", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.t_n_o_m_m_w_s_a_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.t_t_s_i_i_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "l_c_s.t_t_s_i_q_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "l_c_s.t_t_s_i_w_u_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "l_c_s.w_t_i_q_m_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_m.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_m.m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_m.m_u_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_m.r_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_m_u.s_p_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_m_u.u_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.a_d_f_l_s_t_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average_distinct" + }, + { + "nullable": false, + "fieldPath": "m_b_s.a_e_c_p_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "m_b_s.a_i_c_p_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "m_b_s.a_m_c_p_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "m_b_s.a_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "m_b_s.a_t_o_t_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "m_b_s.D_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "m_b_s.e_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum_distinct" + }, + { + "nullable": false, + "fieldPath": "m_b_s.m_u_b_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_b_s.n_f_s_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_b_s.p_r_w_o_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.p_r_w_s_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.p_o_s_i_r_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_s_i_c_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_w_o_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_w_s_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_b_s.s_w_i_r_h_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_b_s.t_r_s_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m.a_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average_distinct" + }, + { + "nullable": false, + "fieldPath": "m.b_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m.c_i_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m.c_i_t_r", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m.c_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m.e_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m.m_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "median" + }, + { + "nullable": false, + "fieldPath": "m.m_s_l", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "median" + }, + { + "nullable": false, + "fieldPath": "m.m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m.p_u_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m.r_b_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m.s_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m.s_i_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_p_m_b_p_s_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average_distinct" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_p_m_b_p_s_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "max" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_i_p_m_b_p_s_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "min" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_t_i_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average_distinct" + }, + { + "nullable": false, + "fieldPath": "m_i_c.a_t_i_a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average_distinct" + }, + { + "nullable": false, + "fieldPath": "m_i_c.c_i_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_i_c.i_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_i_c.i_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_i_c.o_i_n_a_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_i_c.t_t_i_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum_distinct" + }, + { + "nullable": false, + "fieldPath": "o_m_s.a_c_m_l_9_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "o_m_s.a_c_l_9_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "o_m_s.a_r_l_9_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "o_m_s.u_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "q_n_n.n_s_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "q_n_n.n_s_c_1_t_7", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "q_n_n.n_s_c_1_t_9", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "q_n_n.n_s_c_6_t_3", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "q_n_n.n_s_c_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "q_n_n.n_s_c_l_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "q_n_n.n_s_c_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "q_n_n.n_s_c_l_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "q_n_n.n_s_c_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "q_n_n.n_s_c_l_q", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_p_d.a_p_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum_distinct" + }, + { + "nullable": false, + "fieldPath": "s_p_d.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "p_e.a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "p_e.a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "p_e.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "p_e_s.c_e_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count" + }, + { + "nullable": false, + "fieldPath": "p_e.q_p_r_b_l_c_t_b", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_e.q_p_r_b_l_c_t_b_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "p_e.t_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "s_s.a_n_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "s_s.a_n_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "s_s.A_p_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "s_s.a_p_s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "s_s.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count" + }, + { + "nullable": false, + "fieldPath": "s_s.m_p_s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.a_f_r_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.a_f_r_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.a_f_r_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.e_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.s_e_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.s_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_q_f_r_t.s_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_s.c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "o_s.m_w_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "o_s.n_s_a_c_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_s.p_w_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "o_s.p_w_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "o_s.p_w_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "o_s.p_w_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "o_s.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_s.s_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "o_s.u_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.e_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_e.h_c_e_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_e.m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_e.p_o_e_w_h_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_e.r_e_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "running_total" + }, + { + "nullable": false, + "fieldPath": "s_e.r_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "running_total" + }, + { + "nullable": false, + "fieldPath": "s_a_a.a_p_v_p_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "s_a_a.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_v_f.n_s_s_o_v_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_v_f.s_s_o_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_v_f.s_v_o_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_v_f.s_v_a_s_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_a_a.t_s_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_s_u.t_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_a_a.t_v_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_f_l.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count" + }, + { + "nullable": false, + "fieldPath": "s_f_l.f_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_f_l.t_f", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_f_l.t_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_f_l.t_n", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_f_l.t_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_g.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_g.f_g_c_n_e_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_g.f_g_d_l_b_5_a_1_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_g.f_g_s_h_a_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_g.f_g_t_i_3_o_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_g.f_g_t_l_b_2_a_8_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_g.f_g_u_i_l_9_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_g.f_g_v_i_l_9_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_g.f_u_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_g.s_c_h_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_g.t_f_g", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_c_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "s_u_a.a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "s_u_a.t_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "s_u_a.t_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "s_u_a.t_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "s_u_a.t_c_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "s_u_a.t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.a_g_b_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum_distinct" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.a_g_b_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.a_g_b_p_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_g_b.m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_c.c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_c.s_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_c.s_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_c.s_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_c.t_c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_c.t_s_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_c.t_c_p_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_a.s_p_a", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_a.u_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_a_q.c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.a_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.a_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.a_a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.a_a_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.a_a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.a_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.a_e_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.c_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.c_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.C_c_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.C_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.C_c_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.C_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.C_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.C_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.e_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.e_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.e_a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.e_a_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.e_a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.i_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.i_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.i_c_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.i_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.i_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.i_c_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.i_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.l_c_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.l_c_a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.l_c_a_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.l_c_a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.p_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.p_a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.p_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.p_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_c_c_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_c_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_c_c_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_c_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_c_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_c_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_c_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_c_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.S_r_g", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.t_s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.t_s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.v_a_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.v_a_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.v_a_s_r_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.v_a_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "s_d_s_m.s_g", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_h_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_h_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_h_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_a_w_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_t_a_h_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_t_a_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_t_a_w_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_t_h_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_t_h_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_t_t_q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_w_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.e_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.e_u_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.e_u_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_p_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.s_p_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_e_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.a_l_u_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_t_q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_a_f_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_a_h_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_a_h_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_a_t_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_a_w_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_f_t_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_n_f_t_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_p_a_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_t_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_t_u_w_f_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_i_q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_u_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_b_a_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_b_a_p_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.u_p_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.u_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.w_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_a_h.t_s_a_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.a_a_h_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.f_c_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.i_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.i_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.m_c_r_b_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.p_a_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.p_c_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.t_u_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.t_u_p_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.t_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.t_a_h_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "m_s_z_t_c.w_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_c_p_o_a_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_c_t_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_w_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_s_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_c_d_t_f_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_f_d_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_h_t_i_m_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_s_p_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_f_r_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_f_r_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_f_r_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.a_m_t_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.c_f_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.d_m_a_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.e_s_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.e_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.f_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_c_s_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.l_c_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.m_f_r_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.m_f_r_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.p_f_r_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.p_f_r_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.p_f_r_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.p_f_r_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.p_f_r_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.p_f_r_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.p_r_i_1_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_p_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_f_r_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_o_f_r_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_o_t_t_s_w_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.s_o_t_t_s_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_a_h_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_a_h_a_l_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_a_h_l_u_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_a_h_l_u_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_a_h_l_u_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_a_h_l_u_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_a_h_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_a_h_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_a_h_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_a_h_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_v_l_w_v_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_f_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.t_s_p_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.v_s_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.v_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.w_t_e", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.BooleanType": {} + } + }, + "recursive": false, + "nativeDataType": "yesno" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.w_l_c_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.w_a_r_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.w_c_b_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.w_r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.w_r_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.w_s_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.w_s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.w_t_b_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_f_h_o_s.w_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.s_o_t_t_s_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "t_t_s_l_u_h.s_o_t_t_s_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.a_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "p_u.a_r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.a_q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.a_s_q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.a_e_q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "p_u.a_e_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.a_q_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average_distinct" + }, + { + "nullable": false, + "fieldPath": "p_u.c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "p_u.e_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.e_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.c_e_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "p_u.q_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.s_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.s_p_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.s_p_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "p_u.t_e_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum_distinct" + }, + { + "nullable": false, + "fieldPath": "p_u.t_s_m_p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum_distinct" + }, + { + "nullable": false, + "fieldPath": "p_u.t_s_p", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum_distinct" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_w_s_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_v_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_c_w_t_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_c_w_t_s_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_c_w_t_s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_h_t_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_m_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.StringType": {} + } + }, + "recursive": false, + "nativeDataType": "string" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_h_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_s_o_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_v", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_t_s_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_t_s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.c_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.d_c_v", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.h_t_s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.h_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.i_s_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.i_d_c_v", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.n_a_c_v", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum_distinct" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.s_a_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.t_t_s_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.t_h_t", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum_distinct" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.t_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.a_t_h_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.v_a_r_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.w_t_i_q_7_p_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.w_t_i_q_8_p_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.w_t_i_q_9_p_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.w_t_i_q_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "f_c_a_s.w_t_i_q_m_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.a_t_r_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.a_t_r_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.a_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.a_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.a_g_p_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.e_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.e_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.t_t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.t_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t_g_h.v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.l_c_p_o_a_v", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.l_c_t_l", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.a_w_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.a_s_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.a_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.a_c_d_t_f_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_t.a_f_d_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_t.a_h_t_i_m_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.a_s_p_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_t.a_f_r_t_d", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.a_f_r_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.a_f_r_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.a_m_t_a_i_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_t.c_f_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.d_i_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.d_m_a_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "z_t.e_s_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.e_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.f_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.l_c_s_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.l_c_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.m_f_r_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.m_f_r_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t.m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.p_f_r_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.p_f_r_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t.p_f_r_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.p_f_r_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t.p_f_r_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.p_f_r_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t.p_r_i_1_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t_d_d.p_r_w_d_d", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.s_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.s_p_d_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.s_f_r_t_m", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.s_o_f_r_t_s", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.s_o_t_t_s_w_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "z_t.s_o_t_t_s_w_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "z_t.t_a_h_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_t.t_a_h_a_l_u", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_t.t_a_h_l_u_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t.t_a_h_l_u_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t.t_a_h_l_u_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t.t_a_h_l_u_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t.t_a_h_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t.t_a_h_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t.t_a_h_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t.t_a_h_p", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_t.t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.t_v_l_w_v_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.t_f_o", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.t_s_p_a", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "sum" + }, + { + "nullable": false, + "fieldPath": "z_t.v_s_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.v_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.w_l_c_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.w_a_r_i_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.w_r_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.w_r_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.w_s_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.w_s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_t.w_t_b_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_t.w_t_c", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_b_w_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_b_w_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_q_b_t_t_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_q_b_t_t_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_q_b_t_t_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_q_b_t_t_t_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_t_t_f_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_t_t_f_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_i_t_t_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_t_t_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_t_t_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_t_t_s_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_t_t_s_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_t_t_t_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_t_t_t_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_t_t_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "average" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.a_p_t", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.c_f_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.c_f_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.c_s_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.c_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_b_w_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_t_f_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_t_f_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_t_r", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.m_t_t_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_b_w_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "median" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_b_w_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "median" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "median" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_b_w_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_b_w_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_f_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_f_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_b_w_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_b_w_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_f_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_f_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_b_w_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_b_w_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_f_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_f_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_b_w_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_b_w_t_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_f_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_f_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_r_m", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_r_s", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.p_t_t_t_h", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "percentile" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.q_b_s_a_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.q_b_s_c_a_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_1_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_1_r_w_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_2_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_3_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_4_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_a_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "number" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_c_a_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_c_f_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_c_f_r_w_1", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_c_f_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_c_s_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.s_c_t_r_w", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.u_m_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "z_w_r_t.u_t_c", + "description": " ", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + }, + { + "nullable": false, + "fieldPath": "last_of.6800_cols", + "description": "", + "isPartOfKey": false, + "label": " ", + "globalTags": { + "tags": [ + { + "tag": "urn:li:tag:Measure" + } + ] + }, + "type": { + "type": { + "com.linkedin.schema.NumberType": {} + } + }, + "recursive": false, + "nativeDataType": "count_distinct" + } + ], + "schemaName": "test-large-schema", + "version": 0, + "hash": "", + "platform": "urn:li:dataPlatform:looker" + } + } + ] + } + }, + "proposedDelta": null + } +] \ No newline at end of file From c05b89541d53879bd3cb1ae71ab4ba08d702c403 Mon Sep 17 00:00:00 2001 From: Tamas Nemeth Date: Thu, 5 Sep 2024 00:00:24 +0200 Subject: [PATCH 14/34] fix(ingest/prefect): Temporary pinning Prefect 2.x until we can upgrade to 3.x (#11302) --- metadata-ingestion-modules/prefect-plugin/README.md | 4 ++-- metadata-ingestion-modules/prefect-plugin/setup.py | 4 +++- 2 files changed, 5 insertions(+), 3 deletions(-) diff --git a/metadata-ingestion-modules/prefect-plugin/README.md b/metadata-ingestion-modules/prefect-plugin/README.md index 607d93e460c630..0896942e78ef61 100644 --- a/metadata-ingestion-modules/prefect-plugin/README.md +++ b/metadata-ingestion-modules/prefect-plugin/README.md @@ -29,7 +29,7 @@ The `prefect-datahub` collection allows you to easily integrate DataHub's metada ## Prerequisites - Python 3.7+ -- Prefect 2.0.0+ +- Prefect 2.0.0+ and < 3.0.0+ - A running instance of DataHub ## Installation @@ -129,4 +129,4 @@ If you encounter any issues or have questions, you can: ## License -`prefect-datahub` is released under the Apache 2.0 license. See the [LICENSE](https://github.com/datahub-project/datahub/blob/master/LICENSE) file for details. \ No newline at end of file +`prefect-datahub` is released under the Apache 2.0 license. See the [LICENSE](https://github.com/datahub-project/datahub/blob/master/LICENSE) file for details. diff --git a/metadata-ingestion-modules/prefect-plugin/setup.py b/metadata-ingestion-modules/prefect-plugin/setup.py index 746d786f10cbc0..7e56fe8b6ad114 100644 --- a/metadata-ingestion-modules/prefect-plugin/setup.py +++ b/metadata-ingestion-modules/prefect-plugin/setup.py @@ -12,6 +12,7 @@ def get_long_description(): root = os.path.dirname(__file__) return pathlib.Path(os.path.join(root, "README.md")).read_text() + _version: str = package_metadata["__version__"] _self_pin = ( f"=={_version}" @@ -26,7 +27,8 @@ def get_long_description(): # For python 3.7 and importlib-metadata>=5.0.0, build failed with attribute error "importlib-metadata>=4.4.0,<5.0.0; python_version < '3.8'", # Actual dependencies. - "prefect >= 2.0.0", + # Temporary pinning to 2.0.0 until we can upgrade to 3.0.0 + "prefect >= 2.0.0,<3.0.0", *rest_common, # Ignoring the dependency below because it causes issues with the vercel built wheel install # f"acryl-datahub[datahub-rest]{_self_pin}", From 9c7f62a7792809447931f31419e28b2ba8c8fe96 Mon Sep 17 00:00:00 2001 From: Tamas Nemeth Date: Thu, 5 Sep 2024 00:01:03 +0200 Subject: [PATCH 15/34] feat(ingest/athena): Add option to disable partition extraction (#11286) --- .../src/datahub/ingestion/source/sql/athena.py | 10 ++++++++++ 1 file changed, 10 insertions(+) diff --git a/metadata-ingestion/src/datahub/ingestion/source/sql/athena.py b/metadata-ingestion/src/datahub/ingestion/source/sql/athena.py index 5cc51882965a0c..71cfd0268ee6b5 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/sql/athena.py +++ b/metadata-ingestion/src/datahub/ingestion/source/sql/athena.py @@ -266,6 +266,11 @@ class AthenaConfig(SQLCommonConfig): "queries executed by DataHub." ) + extract_partitions: bool = pydantic.Field( + default=True, + description="Extract partitions for tables. Partition extraction needs to run a query (`select * from table$partitions`) on the table. Disable this if you don't want to grant select permission.", + ) + _s3_staging_dir_population = pydantic_renamed_field( old_name="s3_staging_dir", new_name="query_result_location", @@ -460,6 +465,11 @@ def get_partitions( ) -> List[str]: partitions = [] + athena_config = typing.cast(AthenaConfig, self.config) + + if not athena_config.extract_partitions: + return [] + if not self.cursor: return [] From 199c2032b8c5474b9e727bc6018cc6f5a746a302 Mon Sep 17 00:00:00 2001 From: Yuri Niitsuma Date: Thu, 5 Sep 2024 01:39:53 -0300 Subject: [PATCH 16/34] docs(adoption): Add Inter&Co (#11299) --- README.md | 1 + 1 file changed, 1 insertion(+) diff --git a/README.md b/README.md index a0a41b692676ea..1089c4dbc055c4 100644 --- a/README.md +++ b/README.md @@ -133,6 +133,7 @@ Here are the companies that have officially adopted DataHub. Please feel free to - [Haibo Technology](https://www.botech.com.cn) - [hipages](https://hipages.com.au/) - [inovex](https://www.inovex.de/) +- [Inter&Co](https://inter.co/) - [IOMED](https://iomed.health) - [Klarna](https://www.klarna.com) - [LinkedIn](http://linkedin.com) From 07883473b8c485f4f133752e45d2f8834b976aad Mon Sep 17 00:00:00 2001 From: Aseem Bansal Date: Thu, 5 Sep 2024 18:45:54 +0530 Subject: [PATCH 17/34] fix(api/timeline): fix corner cases missed, add tests (#11288) --- .../SchemaMetadataChangeEventGenerator.java | 292 +++++++++--------- ...chemaMetadataChangeEventGeneratorTest.java | 112 +++++++ 2 files changed, 263 insertions(+), 141 deletions(-) diff --git a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/SchemaMetadataChangeEventGenerator.java b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/SchemaMetadataChangeEventGenerator.java index 129a42c0775d7c..0ab55893d48d2a 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/SchemaMetadataChangeEventGenerator.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/timeline/eventgenerator/SchemaMetadataChangeEventGenerator.java @@ -20,12 +20,7 @@ import com.linkedin.schema.SchemaMetadata; import jakarta.json.JsonPatch; import java.net.URISyntaxException; -import java.util.ArrayList; -import java.util.Collections; -import java.util.Comparator; -import java.util.HashSet; -import java.util.List; -import java.util.Set; +import java.util.*; import java.util.stream.Collectors; import javax.annotation.Nonnull; import javax.annotation.Nullable; @@ -208,160 +203,168 @@ private static List getFieldPropertyChangeEvents( return propChangeEvents; } - // TODO: This could use some cleanup, lots of repeated logic and tenuous conditionals + private static Map getSchemaFieldMap(SchemaFieldArray fieldArray) { + Map fieldMap = new HashMap<>(); + fieldArray.forEach(schemaField -> fieldMap.put(schemaField.getFieldPath(), schemaField)); + return fieldMap; + } + + private static void processFieldPathDataTypeChange( + String baseFieldPath, + Urn datasetUrn, + ChangeCategory changeCategory, + AuditStamp auditStamp, + Map baseFieldMap, + Map targetFieldMap, + Set processedBaseFields, + Set processedTargetFields, + List changeEvents) { + SchemaField curBaseField = baseFieldMap.get(baseFieldPath); + if (!targetFieldMap.containsKey(baseFieldPath)) { + return; + } + processedBaseFields.add(baseFieldPath); + processedTargetFields.add(baseFieldPath); + SchemaField curTargetField = targetFieldMap.get(baseFieldPath); + if (!curBaseField.getNativeDataType().equals(curTargetField.getNativeDataType())) { + // Non-backward compatible change + Major version bump + if (ChangeCategory.TECHNICAL_SCHEMA.equals(changeCategory)) { + changeEvents.add( + DatasetSchemaFieldChangeEvent.schemaFieldChangeEventBuilder() + .category(ChangeCategory.TECHNICAL_SCHEMA) + .modifier(getSchemaFieldUrn(datasetUrn, curBaseField).toString()) + .entityUrn(datasetUrn.toString()) + .operation(ChangeOperation.MODIFY) + .semVerChange(SemanticChangeType.MAJOR) + .description( + String.format( + "%s native datatype of the field '%s' changed from '%s' to '%s'.", + BACKWARDS_INCOMPATIBLE_DESC, + getFieldPathV1(curTargetField), + curBaseField.getNativeDataType(), + curTargetField.getNativeDataType())) + .fieldPath(curBaseField.getFieldPath()) + .fieldUrn(getSchemaFieldUrn(datasetUrn, curBaseField)) + .nullable(curBaseField.isNullable()) + .auditStamp(auditStamp) + .build()); + } + List propChangeEvents = + getFieldPropertyChangeEvents( + curBaseField, curTargetField, datasetUrn, changeCategory, auditStamp); + changeEvents.addAll(propChangeEvents); + } + List propChangeEvents = + getFieldPropertyChangeEvents( + curBaseField, curTargetField, datasetUrn, changeCategory, auditStamp); + changeEvents.addAll(propChangeEvents); + } + + private static void processFieldPathRename( + String baseFieldPath, + Urn datasetUrn, + ChangeCategory changeCategory, + AuditStamp auditStamp, + Map baseFieldMap, + Map targetFieldMap, + Set processedBaseFields, + Set processedTargetFields, + List changeEvents, + Set renamedFields) { + + List nonProcessedTargetSchemaFields = new ArrayList<>(); + targetFieldMap.forEach( + (s, schemaField) -> { + if (!processedTargetFields.contains(s)) { + nonProcessedTargetSchemaFields.add(schemaField); + } + }); + + SchemaField curBaseField = baseFieldMap.get(baseFieldPath); + SchemaField renamedField = + findRenamedField(curBaseField, nonProcessedTargetSchemaFields, renamedFields); + processedBaseFields.add(baseFieldPath); + if (renamedField == null) { + processRemoval(changeCategory, changeEvents, datasetUrn, curBaseField, auditStamp); + } else { + if (!ChangeCategory.TECHNICAL_SCHEMA.equals(changeCategory)) { + return; + } + processedTargetFields.add(renamedField.getFieldPath()); + changeEvents.add(generateRenameEvent(datasetUrn, curBaseField, renamedField, auditStamp)); + List propChangeEvents = + getFieldPropertyChangeEvents( + curBaseField, renamedField, datasetUrn, changeCategory, auditStamp); + changeEvents.addAll(propChangeEvents); + } + } + + private static Set getNonProcessedFields( + Map fieldMap, Set processedFields) { + Set nonProcessedFields = new HashSet<>(fieldMap.keySet()); + nonProcessedFields.removeAll(processedFields); + return nonProcessedFields; + } + private static List computeDiffs( SchemaMetadata baseSchema, SchemaMetadata targetSchema, Urn datasetUrn, ChangeCategory changeCategory, AuditStamp auditStamp) { - // Sort the fields by their field path. - if (baseSchema != null) { - sortFieldsByPath(baseSchema); - } - if (targetSchema != null) { - sortFieldsByPath(targetSchema); - } - - // Performs ordinal based diff, primarily based on fixed field ordinals and their types. SchemaFieldArray baseFields = (baseSchema != null ? baseSchema.getFields() : new SchemaFieldArray()); SchemaFieldArray targetFields = targetSchema != null ? targetSchema.getFields() : new SchemaFieldArray(); - int baseFieldIdx = 0; - int targetFieldIdx = 0; + + Map baseFieldMap = getSchemaFieldMap(baseFields); + Map targetFieldMap = getSchemaFieldMap(targetFields); + + Set processedBaseFields = new HashSet<>(); + Set processedTargetFields = new HashSet<>(); + List changeEvents = new ArrayList<>(); Set renamedFields = new HashSet<>(); - while (baseFieldIdx < baseFields.size() && targetFieldIdx < targetFields.size()) { - SchemaField curBaseField = baseFields.get(baseFieldIdx); - SchemaField curTargetField = targetFields.get(targetFieldIdx); - // TODO: Re-evaluate ordinal processing? - int comparison = curBaseField.getFieldPath().compareTo(curTargetField.getFieldPath()); - if (renamedFields.contains(curBaseField)) { - baseFieldIdx++; - } else if (renamedFields.contains(curTargetField)) { - targetFieldIdx++; - } else if (comparison == 0) { - // This is the same field. Check for change events from property changes. - if (!curBaseField.getNativeDataType().equals(curTargetField.getNativeDataType())) { - // Non-backward compatible change + Major version bump - if (ChangeCategory.TECHNICAL_SCHEMA.equals(changeCategory)) { - changeEvents.add( - DatasetSchemaFieldChangeEvent.schemaFieldChangeEventBuilder() - .category(ChangeCategory.TECHNICAL_SCHEMA) - .modifier(getSchemaFieldUrn(datasetUrn, curBaseField).toString()) - .entityUrn(datasetUrn.toString()) - .operation(ChangeOperation.MODIFY) - .semVerChange(SemanticChangeType.MAJOR) - .description( - String.format( - "%s native datatype of the field '%s' changed from '%s' to '%s'.", - BACKWARDS_INCOMPATIBLE_DESC, - getFieldPathV1(curTargetField), - curBaseField.getNativeDataType(), - curTargetField.getNativeDataType())) - .fieldPath(curBaseField.getFieldPath()) - .fieldUrn(getSchemaFieldUrn(datasetUrn, curBaseField)) - .nullable(curBaseField.isNullable()) - .auditStamp(auditStamp) - .build()); - } - List propChangeEvents = - getFieldPropertyChangeEvents( - curBaseField, curTargetField, datasetUrn, changeCategory, auditStamp); - changeEvents.addAll(propChangeEvents); - ++baseFieldIdx; - ++targetFieldIdx; - } - List propChangeEvents = - getFieldPropertyChangeEvents( - curBaseField, curTargetField, datasetUrn, changeCategory, auditStamp); - changeEvents.addAll(propChangeEvents); - ++baseFieldIdx; - ++targetFieldIdx; - } else if (comparison < 0) { - // Base Field was removed or was renamed. Non-backward compatible change + Major version - // bump - // Check for rename, if rename coincides with other modifications we assume drop/add. - // Assumes that two different fields on the same schema would not have the same description, - // terms, - // or tags and share the same type - SchemaField renamedField = - findRenamedField( - curBaseField, - targetFields.subList(targetFieldIdx, targetFields.size()), - renamedFields); - if (renamedField == null) { - processRemoval(changeCategory, changeEvents, datasetUrn, curBaseField, auditStamp); - ++baseFieldIdx; - } else { - changeEvents.add(generateRenameEvent(datasetUrn, curBaseField, renamedField, auditStamp)); - List propChangeEvents = - getFieldPropertyChangeEvents( - curBaseField, curTargetField, datasetUrn, changeCategory, auditStamp); - changeEvents.addAll(propChangeEvents); - ++baseFieldIdx; - renamedFields.add(renamedField); - } - } else { - // The targetField got added or a renaming occurred. Forward & backwards compatible change + - // minor version bump. - SchemaField renamedField = - findRenamedField( - curTargetField, baseFields.subList(baseFieldIdx, baseFields.size()), renamedFields); - if (renamedField == null) { - processAdd(changeCategory, changeEvents, datasetUrn, curTargetField, auditStamp); - ++targetFieldIdx; - } else { - changeEvents.add( - generateRenameEvent(datasetUrn, renamedField, curTargetField, auditStamp)); - List propChangeEvents = - getFieldPropertyChangeEvents( - curBaseField, curTargetField, datasetUrn, changeCategory, auditStamp); - changeEvents.addAll(propChangeEvents); - ++targetFieldIdx; - renamedFields.add(renamedField); - } - } - } - while (baseFieldIdx < baseFields.size()) { - // Handle removed fields. Non-backward compatible change + major version bump - SchemaField baseField = baseFields.get(baseFieldIdx); - if (!renamedFields.contains(baseField)) { - processRemoval(changeCategory, changeEvents, datasetUrn, baseField, auditStamp); - } - ++baseFieldIdx; + + for (String baseFieldPath : baseFieldMap.keySet()) { + processFieldPathDataTypeChange( + baseFieldPath, + datasetUrn, + changeCategory, + auditStamp, + baseFieldMap, + targetFieldMap, + processedBaseFields, + processedTargetFields, + changeEvents); } - while (targetFieldIdx < targetFields.size()) { - // Newly added fields. Forwards & backwards compatible change + minor version bump. - SchemaField targetField = targetFields.get(targetFieldIdx); - if (!renamedFields.contains(targetField)) { - processAdd(changeCategory, changeEvents, datasetUrn, targetField, auditStamp); - } - targetFieldIdx++; + Set nonProcessedBaseFields = getNonProcessedFields(baseFieldMap, processedBaseFields); + for (String baseFieldPath : nonProcessedBaseFields) { + processFieldPathRename( + baseFieldPath, + datasetUrn, + changeCategory, + auditStamp, + baseFieldMap, + targetFieldMap, + processedBaseFields, + processedTargetFields, + changeEvents, + renamedFields); } - // Handle primary key constraint change events. - List primaryKeyChangeEvents = - getPrimaryKeyChangeEvents(baseSchema, targetSchema, datasetUrn, auditStamp); - changeEvents.addAll(primaryKeyChangeEvents); + Set nonProcessedTargetFields = + getNonProcessedFields(targetFieldMap, processedTargetFields); - // Handle foreign key constraint change events. - List foreignKeyChangeEvents = getForeignKeyChangeEvents(); - changeEvents.addAll(foreignKeyChangeEvents); + nonProcessedTargetFields.forEach( + fieldPath -> { + SchemaField curTargetField = targetFieldMap.get(fieldPath); + processAdd(changeCategory, changeEvents, datasetUrn, curTargetField, auditStamp); + }); return changeEvents; } - private static void sortFieldsByPath(SchemaMetadata schemaMetadata) { - if (schemaMetadata == null) { - throw new IllegalArgumentException("SchemaMetadata should not be null"); - } - List schemaFields = new ArrayList<>(schemaMetadata.getFields()); - schemaFields.sort(Comparator.comparing(SchemaField::getFieldPath)); - schemaMetadata.setFields(new SchemaFieldArray(schemaFields)); - } - private static SchemaField findRenamedField( SchemaField curField, List targetFields, Set renamedFields) { return targetFields.stream() @@ -391,7 +394,14 @@ private static boolean parentFieldsMatch(SchemaField curField, SchemaField schem } private static boolean descriptionsMatch(SchemaField curField, SchemaField schemaField) { - return StringUtils.isNotBlank(curField.getDescription()) + if (StringUtils.isBlank(curField.getDescription()) + && StringUtils.isBlank(schemaField.getDescription())) { + return true; + } + return !(StringUtils.isBlank(curField.getDescription()) + && StringUtils.isNotBlank(schemaField.getDescription())) + && !(StringUtils.isNotBlank(curField.getDescription()) + && StringUtils.isBlank(schemaField.getDescription())) && curField.getDescription().equals(schemaField.getDescription()); } diff --git a/metadata-io/src/test/java/com/linkedin/metadata/timeline/eventgenerator/SchemaMetadataChangeEventGeneratorTest.java b/metadata-io/src/test/java/com/linkedin/metadata/timeline/eventgenerator/SchemaMetadataChangeEventGeneratorTest.java index 3e9f1cd0fe092a..ef7b818c593010 100644 --- a/metadata-io/src/test/java/com/linkedin/metadata/timeline/eventgenerator/SchemaMetadataChangeEventGeneratorTest.java +++ b/metadata-io/src/test/java/com/linkedin/metadata/timeline/eventgenerator/SchemaMetadataChangeEventGeneratorTest.java @@ -7,16 +7,128 @@ import com.linkedin.metadata.timeline.data.ChangeEvent; import com.linkedin.mxe.SystemMetadata; import com.linkedin.restli.internal.server.util.DataMapUtils; +import com.linkedin.schema.SchemaField; +import com.linkedin.schema.SchemaFieldArray; import com.linkedin.schema.SchemaMetadata; +import java.net.URISyntaxException; import java.nio.charset.StandardCharsets; +import java.util.HashSet; import java.util.List; import java.util.Map; +import java.util.Set; import org.apache.commons.io.IOUtils; import org.springframework.test.context.testng.AbstractTestNGSpringContextTests; import org.testng.annotations.Test; public class SchemaMetadataChangeEventGeneratorTest extends AbstractTestNGSpringContextTests { + private static Urn getTestUrn() throws URISyntaxException { + return Urn.createFromString("urn:li:dataset:(urn:li:dataPlatform:hdfs,SampleHdfsDataset,PROD)"); + } + + private static AuditStamp getTestAuditStamp() throws URISyntaxException { + return new AuditStamp() + .setActor(Urn.createFromString("urn:li:corpuser:__datahub_system")) + .setTime(1683829509553L); + } + + private static void compareDescriptions( + Set expectedDescriptions, List actual) { + Set actualDescriptions = new HashSet<>(); + actual.forEach( + changeEvent -> { + actualDescriptions.add(changeEvent.getDescription()); + }); + assertEquals(expectedDescriptions, actualDescriptions); + } + + private static Aspect getSchemaMetadata(List schemaFieldList) { + return new Aspect<>( + new SchemaMetadata().setFields(new SchemaFieldArray(schemaFieldList)), + new SystemMetadata()); + } + + @Test + public void testNativeSchemaBackwardIncompatibleChange() throws Exception { + SchemaMetadataChangeEventGenerator test = new SchemaMetadataChangeEventGenerator(); + + Urn urn = getTestUrn(); + String entity = "dataset"; + String aspect = "schemaMetadata"; + AuditStamp auditStamp = getTestAuditStamp(); + + Aspect from = + getSchemaMetadata( + List.of(new SchemaField().setFieldPath("ID").setNativeDataType("NUMBER(16,1)"))); + Aspect to = + getSchemaMetadata( + List.of(new SchemaField().setFieldPath("ID").setNativeDataType("NUMBER(10,1)"))); + List actual = test.getChangeEvents(urn, entity, aspect, from, to, auditStamp); + // Test single field going from NUMBER(16,1) -> NUMBER(10,1) + assertEquals(1, actual.size()); + compareDescriptions( + Set.of( + "A backwards incompatible change due to native datatype of the field 'ID' changed from 'NUMBER(16,1)' to 'NUMBER(10,1)'."), + actual); + + List actual2 = test.getChangeEvents(urn, entity, aspect, to, from, auditStamp); + // Test single field going from NUMBER(10,1) -> NUMBER(16,1) + assertEquals(1, actual2.size()); + compareDescriptions( + Set.of( + "A backwards incompatible change due to native datatype of the field 'ID' changed from 'NUMBER(10,1)' to 'NUMBER(16,1)'."), + actual2); + } + + @Test + public void testNativeSchemaFieldAddition() throws Exception { + SchemaMetadataChangeEventGenerator test = new SchemaMetadataChangeEventGenerator(); + + Urn urn = getTestUrn(); + String entity = "dataset"; + String aspect = "schemaMetadata"; + AuditStamp auditStamp = getTestAuditStamp(); + + Aspect from = + getSchemaMetadata( + List.of(new SchemaField().setFieldPath("ID").setNativeDataType("NUMBER(16,1)"))); + Aspect to3 = + getSchemaMetadata( + List.of( + new SchemaField().setFieldPath("aa").setNativeDataType("NUMBER(10,1)"), + new SchemaField().setFieldPath("ID").setNativeDataType("NUMBER(10,1)"))); + List actual = test.getChangeEvents(urn, entity, aspect, from, to3, auditStamp); + assertEquals(2, actual.size()); + compareDescriptions( + Set.of( + "A backwards incompatible change due to native datatype of the field 'ID' changed from 'NUMBER(16,1)' to 'NUMBER(10,1)'.", + "A forwards & backwards compatible change due to the newly added field 'aa'."), + actual); + } + + @Test + public void testSchemaFieldRename() throws Exception { + SchemaMetadataChangeEventGenerator test = new SchemaMetadataChangeEventGenerator(); + + Urn urn = getTestUrn(); + String entity = "dataset"; + String aspect = "schemaMetadata"; + AuditStamp auditStamp = getTestAuditStamp(); + + Aspect from = + getSchemaMetadata( + List.of(new SchemaField().setFieldPath("ID").setNativeDataType("NUMBER(16,1)"))); + Aspect to3 = + getSchemaMetadata( + List.of(new SchemaField().setFieldPath("ID2").setNativeDataType("NUMBER(16,1)"))); + List actual = test.getChangeEvents(urn, entity, aspect, from, to3, auditStamp); + compareDescriptions( + Set.of( + "A forwards & backwards compatible change due to renaming of the field 'ID to ID2'."), + actual); + assertEquals(1, actual.size()); + } + @Test public void testDelete() throws Exception { SchemaMetadataChangeEventGenerator test = new SchemaMetadataChangeEventGenerator(); From d7231161fc209fefd64225ed869a9ec80e0dba22 Mon Sep 17 00:00:00 2001 From: david-leifker <114954101+david-leifker@users.noreply.github.com> Date: Thu, 5 Sep 2024 09:15:57 -0500 Subject: [PATCH 18/34] config(kafka): clean-up kafka serializer config (#11303) --- .../app/client/KafkaTrackingProducer.java | 15 ++- .../upgrade/config/SystemUpdateConfig.java | 9 +- .../DatahubUpgradeNoSchemaRegistryTest.java | 14 ++- .../DatahubUpgradeNonBlockingTest.java | 12 +- .../config/kafka/KafkaConfiguration.java | 115 ++++++++++++++++++ .../src/main/resources/application.yaml | 17 +++ .../kafka/DataHubKafkaProducerFactory.java | 14 +-- .../kafka/KafkaEventConsumerFactory.java | 26 ++-- .../AwsGlueSchemaRegistryFactory.java | 17 ++- .../InternalSchemaRegistryFactory.java | 8 +- .../KafkaSchemaRegistryFactory.java | 12 +- .../schemaregistry/SchemaRegistryConfig.java | 11 -- .../SystemUpdateSchemaRegistryFactory.java | 14 ++- 13 files changed, 209 insertions(+), 75 deletions(-) delete mode 100644 metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/SchemaRegistryConfig.java diff --git a/datahub-frontend/app/client/KafkaTrackingProducer.java b/datahub-frontend/app/client/KafkaTrackingProducer.java index b7173684b63500..058e75100c24ac 100644 --- a/datahub-frontend/app/client/KafkaTrackingProducer.java +++ b/datahub-frontend/app/client/KafkaTrackingProducer.java @@ -1,5 +1,6 @@ package client; +import com.linkedin.metadata.config.kafka.KafkaConfiguration; import com.linkedin.metadata.config.kafka.ProducerConfiguration; import com.typesafe.config.Config; import config.ConfigurationProvider; @@ -46,7 +47,7 @@ public KafkaTrackingProducer( if (_isEnabled) { _logger.debug("Analytics tracking is enabled"); - _producer = createKafkaProducer(config, configurationProvider.getKafka().getProducer()); + _producer = createKafkaProducer(config, configurationProvider.getKafka()); lifecycle.addStopHook( () -> { @@ -69,7 +70,8 @@ public void send(ProducerRecord record) { } private static KafkaProducer createKafkaProducer( - Config config, ProducerConfiguration producerConfiguration) { + Config config, KafkaConfiguration kafkaConfiguration) { + final ProducerConfiguration producerConfiguration = kafkaConfiguration.getProducer(); final Properties props = new Properties(); props.put(ProducerConfig.CLIENT_ID_CONFIG, "datahub-frontend"); props.put( @@ -78,12 +80,9 @@ private static KafkaProducer createKafkaProducer( props.put( ProducerConfig.BOOTSTRAP_SERVERS_CONFIG, config.getString("analytics.kafka.bootstrap.server")); - props.put( - ProducerConfig.KEY_SERIALIZER_CLASS_CONFIG, - "org.apache.kafka.common.serialization.StringSerializer"); // Actor urn. - props.put( - ProducerConfig.VALUE_SERIALIZER_CLASS_CONFIG, - "org.apache.kafka.common.serialization.StringSerializer"); // JSON object. + // key: Actor urn. + // value: JSON object. + props.putAll(kafkaConfiguration.getSerde().getUsageEvent().getProducerProperties(null)); props.put(ProducerConfig.MAX_REQUEST_SIZE_CONFIG, producerConfiguration.getMaxRequestSize()); props.put(ProducerConfig.COMPRESSION_TYPE_CONFIG, producerConfiguration.getCompressionType()); diff --git a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/config/SystemUpdateConfig.java b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/config/SystemUpdateConfig.java index 9c0c82dba65be6..dea98c5cbcb132 100644 --- a/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/config/SystemUpdateConfig.java +++ b/datahub-upgrade/src/main/java/com/linkedin/datahub/upgrade/config/SystemUpdateConfig.java @@ -11,7 +11,6 @@ import com.linkedin.gms.factory.kafka.DataHubKafkaProducerFactory; import com.linkedin.gms.factory.kafka.common.TopicConventionFactory; import com.linkedin.gms.factory.kafka.schemaregistry.InternalSchemaRegistryFactory; -import com.linkedin.gms.factory.kafka.schemaregistry.SchemaRegistryConfig; import com.linkedin.gms.factory.search.BaseElasticSearchComponentsFactory; import com.linkedin.metadata.aspect.GraphRetriever; import com.linkedin.metadata.config.kafka.KafkaConfiguration; @@ -98,7 +97,8 @@ public DataHubStartupStep dataHubStartupStep( protected KafkaEventProducer duheKafkaEventProducer( @Qualifier("configurationProvider") ConfigurationProvider provider, KafkaProperties properties, - @Qualifier("duheSchemaRegistryConfig") SchemaRegistryConfig duheSchemaRegistryConfig) { + @Qualifier("duheSchemaRegistryConfig") + KafkaConfiguration.SerDeKeyValueConfig duheSchemaRegistryConfig) { KafkaConfiguration kafkaConfiguration = provider.getKafka(); Producer producer = new KafkaProducer<>( @@ -130,8 +130,9 @@ protected KafkaEventProducer kafkaEventProducer( @ConditionalOnProperty( name = "kafka.schemaRegistry.type", havingValue = InternalSchemaRegistryFactory.TYPE) - protected SchemaRegistryConfig schemaRegistryConfig( - @Qualifier("duheSchemaRegistryConfig") SchemaRegistryConfig duheSchemaRegistryConfig) { + protected KafkaConfiguration.SerDeKeyValueConfig schemaRegistryConfig( + @Qualifier("duheSchemaRegistryConfig") + KafkaConfiguration.SerDeKeyValueConfig duheSchemaRegistryConfig) { return duheSchemaRegistryConfig; } diff --git a/datahub-upgrade/src/test/java/com/linkedin/datahub/upgrade/DatahubUpgradeNoSchemaRegistryTest.java b/datahub-upgrade/src/test/java/com/linkedin/datahub/upgrade/DatahubUpgradeNoSchemaRegistryTest.java index ffc5d8d765f659..68dfd71ac10044 100644 --- a/datahub-upgrade/src/test/java/com/linkedin/datahub/upgrade/DatahubUpgradeNoSchemaRegistryTest.java +++ b/datahub-upgrade/src/test/java/com/linkedin/datahub/upgrade/DatahubUpgradeNoSchemaRegistryTest.java @@ -7,9 +7,9 @@ import static org.testng.Assert.assertNotNull; import com.linkedin.datahub.upgrade.system.SystemUpdate; -import com.linkedin.gms.factory.kafka.schemaregistry.SchemaRegistryConfig; import com.linkedin.metadata.boot.kafka.MockSystemUpdateDeserializer; import com.linkedin.metadata.boot.kafka.MockSystemUpdateSerializer; +import com.linkedin.metadata.config.kafka.KafkaConfiguration; import com.linkedin.metadata.dao.producer.KafkaEventProducer; import com.linkedin.metadata.entity.EntityServiceImpl; import com.linkedin.mxe.Topics; @@ -55,7 +55,7 @@ public class DatahubUpgradeNoSchemaRegistryTest extends AbstractTestNGSpringCont @Autowired @Named("schemaRegistryConfig") - private SchemaRegistryConfig schemaRegistryConfig; + private KafkaConfiguration.SerDeKeyValueConfig schemaRegistryConfig; @Test public void testSystemUpdateInit() { @@ -64,13 +64,17 @@ public void testSystemUpdateInit() { @Test public void testSystemUpdateKafkaProducerOverride() throws RestClientException, IOException { - assertEquals(schemaRegistryConfig.getDeserializer(), MockSystemUpdateDeserializer.class); - assertEquals(schemaRegistryConfig.getSerializer(), MockSystemUpdateSerializer.class); + assertEquals( + schemaRegistryConfig.getValue().getDeserializer(), + MockSystemUpdateDeserializer.class.getName()); + assertEquals( + schemaRegistryConfig.getValue().getSerializer(), + MockSystemUpdateSerializer.class.getName()); assertEquals(kafkaEventProducer, duheKafkaEventProducer); assertEquals(entityService.getProducer(), duheKafkaEventProducer); MockSystemUpdateSerializer serializer = new MockSystemUpdateSerializer(); - serializer.configure(schemaRegistryConfig.getProperties(), false); + serializer.configure(schemaRegistryConfig.getProperties(null), false); SchemaRegistryClient registry = serializer.getSchemaRegistryClient(); assertEquals( registry.getId( diff --git a/datahub-upgrade/src/test/java/com/linkedin/datahub/upgrade/DatahubUpgradeNonBlockingTest.java b/datahub-upgrade/src/test/java/com/linkedin/datahub/upgrade/DatahubUpgradeNonBlockingTest.java index 154b1de71f46cd..55a52f072a0caf 100644 --- a/datahub-upgrade/src/test/java/com/linkedin/datahub/upgrade/DatahubUpgradeNonBlockingTest.java +++ b/datahub-upgrade/src/test/java/com/linkedin/datahub/upgrade/DatahubUpgradeNonBlockingTest.java @@ -10,9 +10,9 @@ import com.linkedin.datahub.upgrade.impl.DefaultUpgradeManager; import com.linkedin.datahub.upgrade.system.SystemUpdateNonBlocking; import com.linkedin.datahub.upgrade.system.vianodes.ReindexDataJobViaNodesCLL; -import com.linkedin.gms.factory.kafka.schemaregistry.SchemaRegistryConfig; import com.linkedin.metadata.boot.kafka.MockSystemUpdateDeserializer; import com.linkedin.metadata.boot.kafka.MockSystemUpdateSerializer; +import com.linkedin.metadata.config.kafka.KafkaConfiguration; import com.linkedin.metadata.dao.producer.KafkaEventProducer; import com.linkedin.metadata.entity.AspectDao; import com.linkedin.metadata.entity.EntityService; @@ -47,7 +47,7 @@ public class DatahubUpgradeNonBlockingTest extends AbstractTestNGSpringContextTe @Autowired @Named("schemaRegistryConfig") - private SchemaRegistryConfig schemaRegistryConfig; + private KafkaConfiguration.SerDeKeyValueConfig schemaRegistryConfig; @Autowired @Named("duheKafkaEventProducer") @@ -66,8 +66,12 @@ public void testSystemUpdateNonBlockingInit() { assertNotNull(systemUpdateNonBlocking); // Expected system update configuration and producer - assertEquals(schemaRegistryConfig.getDeserializer(), MockSystemUpdateDeserializer.class); - assertEquals(schemaRegistryConfig.getSerializer(), MockSystemUpdateSerializer.class); + assertEquals( + schemaRegistryConfig.getValue().getDeserializer(), + MockSystemUpdateDeserializer.class.getName()); + assertEquals( + schemaRegistryConfig.getValue().getSerializer(), + MockSystemUpdateSerializer.class.getName()); assertEquals(duheKafkaEventProducer, kafkaEventProducer); assertEquals(entityService.getProducer(), duheKafkaEventProducer); } diff --git a/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/kafka/KafkaConfiguration.java b/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/kafka/KafkaConfiguration.java index 2345f88352c170..b03aedc1a7b5eb 100644 --- a/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/kafka/KafkaConfiguration.java +++ b/metadata-service/configuration/src/main/java/com/linkedin/metadata/config/kafka/KafkaConfiguration.java @@ -1,9 +1,25 @@ package com.linkedin.metadata.config.kafka; +import java.util.HashMap; +import java.util.Map; +import lombok.AllArgsConstructor; +import lombok.Builder; import lombok.Data; +import lombok.NoArgsConstructor; +import lombok.NonNull; +import org.springframework.lang.Nullable; @Data public class KafkaConfiguration { + // Avoiding dependencies on other libraries (Spring/Kafka) for configuration + public static final String KEY_SERIALIZER_CLASS_CONFIG = "key.serializer"; + public static final String VALUE_SERIALIZER_CLASS_CONFIG = "value.serializer"; + public static final String KEY_DESERIALIZER_CLASS_CONFIG = "key.deserializer"; + public static final String VALUE_DESERIALIZER_CLASS_CONFIG = "value.deserializer"; + public static final String KEY_DESERIALIZER_DELEGATE_CLASS = + "spring.deserializer.key.delegate.class"; + public static final String VALUE_DESERIALIZER_DELEGATE_CLASS = + "spring.deserializer.value.delegate.class"; private String bootstrapServers; @@ -14,4 +30,103 @@ public class KafkaConfiguration { private ProducerConfiguration producer; private ConsumerConfiguration consumer; + + private SerDeConfig serde; + + @Data + public static class SerDeConfig { + private SerDeKeyValueConfig usageEvent; + private SerDeKeyValueConfig event; + } + + @Data + @Builder(toBuilder = true) + @AllArgsConstructor + @NoArgsConstructor + public static class SerDeKeyValueConfig { + private SerDeProperties key; + private SerDeProperties value; + @Nullable private Map properties; + + protected Map getProperties() { + return getProperties(null); + } + + public Map getProperties(@Nullable SerDeKeyValueConfig schemaRegistryConfig) { + final HashMap props = + new HashMap<>(properties != null ? properties : Map.of()); + if (schemaRegistryConfig != null) { + props.putAll(schemaRegistryConfig.getProperties()); + } + return props; + } + + public Map getProducerProperties( + @Nullable SerDeKeyValueConfig schemaRegistryConfig) { + final SerDeKeyValueConfig config = + schemaRegistryConfig == null ? this : withSchemaRegistryOverride(schemaRegistryConfig); + return Map.of( + KEY_SERIALIZER_CLASS_CONFIG, config.getKey().getSerializer(), + VALUE_SERIALIZER_CLASS_CONFIG, config.getValue().getSerializer()); + } + + public Map getConsumerProperties( + @Nullable SerDeKeyValueConfig schemaRegistryConfig) { + final SerDeKeyValueConfig config = + schemaRegistryConfig == null ? this : withSchemaRegistryOverride(schemaRegistryConfig); + + HashMap consumerProperties = + new HashMap<>( + Map.of( + KEY_DESERIALIZER_CLASS_CONFIG, config.getKey().getDeserializer(), + VALUE_DESERIALIZER_CLASS_CONFIG, config.getValue().getDeserializer())); + + if (config.getKey().getDelegateDeserializer() == null + && config.getValue().getDelegateDeserializer() == null) { + return consumerProperties; + } + + if (config.getKey().getDelegateDeserializer() != null) { + consumerProperties.put( + KEY_DESERIALIZER_DELEGATE_CLASS, config.getKey().getDelegateDeserializer()); + } + if (config.getValue().getDelegateDeserializer() != null) { + consumerProperties.put( + VALUE_DESERIALIZER_DELEGATE_CLASS, config.getValue().getDelegateDeserializer()); + } + + return consumerProperties; + } + + public SerDeKeyValueConfig withSchemaRegistryOverride( + @NonNull SerDeKeyValueConfig schemaRegistryConfig) { + // Handle case where delegation is used, but missing from schemaRegistryConfig + return schemaRegistryConfig.toBuilder() + .key(key.withSchemaRegistryOverride(schemaRegistryConfig.getKey())) + .value(value.withSchemaRegistryOverride(schemaRegistryConfig.getValue())) + .build(); + } + } + + @Data + @Builder(toBuilder = true) + @AllArgsConstructor + @NoArgsConstructor + public static class SerDeProperties { + private String serializer; + private String deserializer; + @Nullable private String delegateDeserializer; + + public SerDeProperties withSchemaRegistryOverride( + @NonNull SerDeProperties schemaRegistryOverride) { + if (delegateDeserializer != null + && schemaRegistryOverride.getDelegateDeserializer() == null) { + return schemaRegistryOverride.toBuilder() + .delegateDeserializer(schemaRegistryOverride.getDeserializer()) + .deserializer(deserializer) + .build(); + } + return schemaRegistryOverride; + } + } } diff --git a/metadata-service/configuration/src/main/resources/application.yaml b/metadata-service/configuration/src/main/resources/application.yaml index 8a667ca056a35c..0977c64d0e8609 100644 --- a/metadata-service/configuration/src/main/resources/application.yaml +++ b/metadata-service/configuration/src/main/resources/application.yaml @@ -250,6 +250,23 @@ kafka: listener: concurrency: ${KAFKA_LISTENER_CONCURRENCY:1} bootstrapServers: ${KAFKA_BOOTSTRAP_SERVER:http://localhost:9092} + serde: + usageEvent: + key: + serializer: ${KAFKA_SERDE_USAGE_EVENTS_KEY_SERIALIZER:org.apache.kafka.common.serialization.StringSerializer} + deserializer: ${KAFKA_SERDE_USAGE_EVENTS_KEY_DESERIALIZER:org.apache.kafka.common.serialization.StringDeserializer} + value: + serializer: ${KAFKA_SERDE_USAGE_EVENTS_VALUE_SERIALIZER:org.apache.kafka.common.serialization.StringSerializer} + deserializer: ${KAFKA_SERDE_USAGE_EVENTS_VALUE_DESERIALIZER:org.apache.kafka.common.serialization.StringDeserializer} + event: + key: + serializer: ${KAFKA_SERDE_EVENT_KEY_SERIALIZER:org.apache.kafka.common.serialization.StringSerializer} + deserializer: ${KAFKA_SERDE_EVENT_KEY_DESERIALIZER:org.springframework.kafka.support.serializer.ErrorHandlingDeserializer} + delegateDeserializer: ${KAFKA_SERDE_EVENT_KEY_DELEGATE_DESERIALIZER:org.apache.kafka.common.serialization.StringDeserializer} + value: + serializer: ${KAFKA_SERDE_EVENT_VALUE_SERIALIZER:io.confluent.kafka.serializers.KafkaAvroSerializer} + deserializer: ${KAFKA_SERDE_EVENT_VALUE_DESERIALIZER:org.springframework.kafka.support.serializer.ErrorHandlingDeserializer} + delegateDeserializer: ${KAFKA_SERDE_EVENT_VALUE_DELEGATE_DESERIALIZER:io.confluent.kafka.serializers.KafkaAvroDeserializer} producer: retryCount: ${KAFKA_PRODUCER_RETRY_COUNT:3} deliveryTimeout: ${KAFKA_PRODUCER_DELIVERY_TIMEOUT:30000} diff --git a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/DataHubKafkaProducerFactory.java b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/DataHubKafkaProducerFactory.java index 6a2b9f511b79f8..6966a195f11606 100644 --- a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/DataHubKafkaProducerFactory.java +++ b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/DataHubKafkaProducerFactory.java @@ -1,7 +1,6 @@ package com.linkedin.gms.factory.kafka; import com.linkedin.gms.factory.config.ConfigurationProvider; -import com.linkedin.gms.factory.kafka.schemaregistry.SchemaRegistryConfig; import com.linkedin.metadata.config.kafka.KafkaConfiguration; import java.util.Arrays; import java.util.Map; @@ -24,14 +23,15 @@ public class DataHubKafkaProducerFactory { protected Producer createInstance( @Qualifier("configurationProvider") ConfigurationProvider provider, final KafkaProperties properties, - @Qualifier("schemaRegistryConfig") final SchemaRegistryConfig schemaRegistryConfig) { + @Qualifier("schemaRegistryConfig") + final KafkaConfiguration.SerDeKeyValueConfig schemaRegistryConfig) { KafkaConfiguration kafkaConfiguration = provider.getKafka(); return new KafkaProducer<>( buildProducerProperties(schemaRegistryConfig, kafkaConfiguration, properties)); } public static Map buildProducerProperties( - SchemaRegistryConfig schemaRegistryConfig, + KafkaConfiguration.SerDeKeyValueConfig schemaRegistryConfig, KafkaConfiguration kafkaConfiguration, KafkaProperties properties) { KafkaProperties.Producer producerProps = properties.getProducer(); @@ -45,8 +45,8 @@ public static Map buildProducerProperties( } // else we rely on KafkaProperties which defaults to localhost:9092 Map props = properties.buildProducerProperties(null); - - props.put(ProducerConfig.VALUE_SERIALIZER_CLASS_CONFIG, schemaRegistryConfig.getSerializer()); + props.putAll( + kafkaConfiguration.getSerde().getEvent().getProducerProperties(schemaRegistryConfig)); props.put(ProducerConfig.RETRIES_CONFIG, kafkaConfiguration.getProducer().getRetryCount()); props.put( @@ -66,9 +66,7 @@ public static Map buildProducerProperties( kafkaConfiguration.getProducer().getMaxRequestSize()); // Override KafkaProperties with SchemaRegistryConfig only for non-empty values - schemaRegistryConfig.getProperties().entrySet().stream() - .filter(entry -> entry.getValue() != null && !entry.getValue().toString().isEmpty()) - .forEach(entry -> props.put(entry.getKey(), entry.getValue())); + props.putAll(kafkaConfiguration.getSerde().getEvent().getProperties(schemaRegistryConfig)); return props; } diff --git a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/KafkaEventConsumerFactory.java b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/KafkaEventConsumerFactory.java index aecb4f0afb12cc..750af8ec488df3 100644 --- a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/KafkaEventConsumerFactory.java +++ b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/KafkaEventConsumerFactory.java @@ -1,7 +1,6 @@ package com.linkedin.gms.factory.kafka; import com.linkedin.gms.factory.config.ConfigurationProvider; -import com.linkedin.gms.factory.kafka.schemaregistry.SchemaRegistryConfig; import com.linkedin.metadata.config.kafka.KafkaConfiguration; import java.time.Duration; import java.util.Arrays; @@ -9,7 +8,6 @@ import lombok.extern.slf4j.Slf4j; import org.apache.avro.generic.GenericRecord; import org.apache.kafka.clients.consumer.ConsumerConfig; -import org.apache.kafka.common.serialization.StringDeserializer; import org.springframework.beans.factory.annotation.Qualifier; import org.springframework.boot.autoconfigure.kafka.KafkaProperties; import org.springframework.context.annotation.Bean; @@ -21,7 +19,6 @@ import org.springframework.kafka.listener.CommonDelegatingErrorHandler; import org.springframework.kafka.listener.DefaultErrorHandler; import org.springframework.kafka.support.serializer.DeserializationException; -import org.springframework.kafka.support.serializer.ErrorHandlingDeserializer; @Slf4j @Configuration @@ -33,7 +30,8 @@ public class KafkaEventConsumerFactory { protected DefaultKafkaConsumerFactory createConsumerFactory( @Qualifier("configurationProvider") ConfigurationProvider provider, KafkaProperties baseKafkaProperties, - @Qualifier("schemaRegistryConfig") SchemaRegistryConfig schemaRegistryConfig) { + @Qualifier("schemaRegistryConfig") + KafkaConfiguration.SerDeKeyValueConfig schemaRegistryConfig) { kafkaEventConsumerConcurrency = provider.getKafka().getListener().getConcurrency(); KafkaConfiguration kafkaConfiguration = provider.getKafka(); @@ -47,7 +45,8 @@ protected DefaultKafkaConsumerFactory createConsumerFacto protected DefaultKafkaConsumerFactory duheKafkaConsumerFactory( @Qualifier("configurationProvider") ConfigurationProvider provider, KafkaProperties baseKafkaProperties, - @Qualifier("duheSchemaRegistryConfig") SchemaRegistryConfig schemaRegistryConfig) { + @Qualifier("duheSchemaRegistryConfig") + KafkaConfiguration.SerDeKeyValueConfig schemaRegistryConfig) { KafkaConfiguration kafkaConfiguration = provider.getKafka(); Map customizedProperties = @@ -59,7 +58,7 @@ protected DefaultKafkaConsumerFactory duheKafkaConsumerFa private static Map buildCustomizedProperties( KafkaProperties baseKafkaProperties, KafkaConfiguration kafkaConfiguration, - SchemaRegistryConfig schemaRegistryConfig) { + KafkaConfiguration.SerDeKeyValueConfig schemaRegistryConfig) { KafkaProperties.Consumer consumerProps = baseKafkaProperties.getConsumer(); // Records will be flushed every 10 seconds. @@ -74,19 +73,12 @@ private static Map buildCustomizedProperties( } // else we rely on KafkaProperties which defaults to localhost:9092 Map customizedProperties = baseKafkaProperties.buildConsumerProperties(null); - customizedProperties.put( - ConsumerConfig.KEY_DESERIALIZER_CLASS_CONFIG, ErrorHandlingDeserializer.class); - customizedProperties.put( - ErrorHandlingDeserializer.KEY_DESERIALIZER_CLASS, StringDeserializer.class); - customizedProperties.put( - ConsumerConfig.VALUE_DESERIALIZER_CLASS_CONFIG, ErrorHandlingDeserializer.class); - customizedProperties.put( - ErrorHandlingDeserializer.VALUE_DESERIALIZER_CLASS, schemaRegistryConfig.getDeserializer()); + customizedProperties.putAll( + kafkaConfiguration.getSerde().getEvent().getConsumerProperties(schemaRegistryConfig)); // Override KafkaProperties with SchemaRegistryConfig only for non-empty values - schemaRegistryConfig.getProperties().entrySet().stream() - .filter(entry -> entry.getValue() != null && !entry.getValue().toString().isEmpty()) - .forEach(entry -> customizedProperties.put(entry.getKey(), entry.getValue())); + customizedProperties.putAll( + kafkaConfiguration.getSerde().getEvent().getProperties(schemaRegistryConfig)); customizedProperties.put( ConsumerConfig.MAX_PARTITION_FETCH_BYTES_CONFIG, diff --git a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/AwsGlueSchemaRegistryFactory.java b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/AwsGlueSchemaRegistryFactory.java index 91dce49e5b0b59..6bebe77859d67c 100644 --- a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/AwsGlueSchemaRegistryFactory.java +++ b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/AwsGlueSchemaRegistryFactory.java @@ -5,6 +5,7 @@ import com.amazonaws.services.schemaregistry.utils.AWSSchemaRegistryConstants; import com.amazonaws.services.schemaregistry.utils.AvroRecordType; import com.linkedin.gms.factory.config.ConfigurationProvider; +import com.linkedin.metadata.config.kafka.KafkaConfiguration; import java.util.HashMap; import java.util.Map; import java.util.Optional; @@ -32,8 +33,9 @@ public class AwsGlueSchemaRegistryFactory { @Bean("schemaRegistryConfig") @Nonnull - protected SchemaRegistryConfig getInstance(final ConfigurationProvider configurationProvider) { - Map props = new HashMap<>(); + protected KafkaConfiguration.SerDeKeyValueConfig getInstance( + final ConfigurationProvider configurationProvider) { + Map props = new HashMap<>(); // FIXME: Properties for this factory should come from ConfigurationProvider object, // specifically under the // KafkaConfiguration class. See InternalSchemaRegistryFactory as an example. @@ -43,7 +45,14 @@ protected SchemaRegistryConfig getInstance(final ConfigurationProvider configura props.put(AWSSchemaRegistryConstants.AVRO_RECORD_TYPE, AvroRecordType.GENERIC_RECORD.getName()); registryName.ifPresent(s -> props.put(AWSSchemaRegistryConstants.REGISTRY_NAME, s)); log.info("Creating AWS Glue registry"); - return new SchemaRegistryConfig( - GlueSchemaRegistryKafkaSerializer.class, GlueSchemaRegistryKafkaDeserializer.class, props); + return KafkaConfiguration.SerDeKeyValueConfig.builder() + .key(configurationProvider.getKafka().getSerde().getEvent().getKey()) + .value( + KafkaConfiguration.SerDeProperties.builder() + .serializer(GlueSchemaRegistryKafkaSerializer.class.getName()) + .deserializer(GlueSchemaRegistryKafkaDeserializer.class.getName()) + .build()) + .properties(props) + .build(); } } diff --git a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/InternalSchemaRegistryFactory.java b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/InternalSchemaRegistryFactory.java index 46b27195ecc675..a3a3989ec1867f 100644 --- a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/InternalSchemaRegistryFactory.java +++ b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/InternalSchemaRegistryFactory.java @@ -3,8 +3,6 @@ import com.linkedin.gms.factory.config.ConfigurationProvider; import com.linkedin.metadata.config.kafka.KafkaConfiguration; import io.confluent.kafka.serializers.AbstractKafkaSchemaSerDeConfig; -import io.confluent.kafka.serializers.KafkaAvroDeserializer; -import io.confluent.kafka.serializers.KafkaAvroSerializer; import java.util.HashMap; import java.util.Map; import javax.annotation.Nonnull; @@ -26,9 +24,9 @@ public class InternalSchemaRegistryFactory { /** Configure Kafka Producer/Consumer processes with a custom schema registry. */ @Bean("schemaRegistryConfig") @Nonnull - protected SchemaRegistryConfig getInstance( + protected KafkaConfiguration.SerDeKeyValueConfig getInstance( @Qualifier("configurationProvider") ConfigurationProvider provider) { - Map props = new HashMap<>(); + Map props = new HashMap<>(); KafkaConfiguration kafkaConfiguration = provider.getKafka(); props.put( @@ -38,6 +36,6 @@ protected SchemaRegistryConfig getInstance( log.info( "Creating internal registry configuration for url {}", kafkaConfiguration.getSchemaRegistry().getUrl()); - return new SchemaRegistryConfig(KafkaAvroSerializer.class, KafkaAvroDeserializer.class, props); + return provider.getKafka().getSerde().getEvent().toBuilder().properties(props).build(); } } diff --git a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/KafkaSchemaRegistryFactory.java b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/KafkaSchemaRegistryFactory.java index e72fbf97e52c98..01e68f334e97ce 100644 --- a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/KafkaSchemaRegistryFactory.java +++ b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/KafkaSchemaRegistryFactory.java @@ -1,10 +1,9 @@ package com.linkedin.gms.factory.kafka.schemaregistry; import com.linkedin.gms.factory.config.ConfigurationProvider; +import com.linkedin.metadata.config.kafka.KafkaConfiguration; import io.confluent.kafka.schemaregistry.client.SchemaRegistryClientConfig; import io.confluent.kafka.serializers.AbstractKafkaSchemaSerDeConfig; -import io.confluent.kafka.serializers.KafkaAvroDeserializer; -import io.confluent.kafka.serializers.KafkaAvroSerializer; import java.util.HashMap; import java.util.Map; import javax.annotation.Nonnull; @@ -43,8 +42,9 @@ public class KafkaSchemaRegistryFactory { @Bean("schemaRegistryConfig") @Nonnull - protected SchemaRegistryConfig getInstance(ConfigurationProvider configurationProvider) { - Map props = new HashMap<>(); + protected KafkaConfiguration.SerDeKeyValueConfig getInstance( + ConfigurationProvider configurationProvider) { + Map props = new HashMap<>(); // FIXME: Properties for this factory should come from ConfigurationProvider object, // specifically under the // KafkaConfiguration class. See InternalSchemaRegistryFactory as an example. @@ -65,7 +65,9 @@ protected SchemaRegistryConfig getInstance(ConfigurationProvider configurationPr sslKeystoreLocation); } - return new SchemaRegistryConfig(KafkaAvroSerializer.class, KafkaAvroDeserializer.class, props); + return configurationProvider.getKafka().getSerde().getEvent().toBuilder() + .properties(props) + .build(); } private String withNamespace(String configKey) { diff --git a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/SchemaRegistryConfig.java b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/SchemaRegistryConfig.java deleted file mode 100644 index 004a7abb884896..00000000000000 --- a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/SchemaRegistryConfig.java +++ /dev/null @@ -1,11 +0,0 @@ -package com.linkedin.gms.factory.kafka.schemaregistry; - -import java.util.Map; -import lombok.Data; - -@Data -public class SchemaRegistryConfig { - private final Class serializer; - private final Class deserializer; - private final Map properties; -} diff --git a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/SystemUpdateSchemaRegistryFactory.java b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/SystemUpdateSchemaRegistryFactory.java index 9f2e7f60793a3e..d1c449e70dc846 100644 --- a/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/SystemUpdateSchemaRegistryFactory.java +++ b/metadata-service/factories/src/main/java/com/linkedin/gms/factory/kafka/schemaregistry/SystemUpdateSchemaRegistryFactory.java @@ -40,9 +40,9 @@ public class SystemUpdateSchemaRegistryFactory { /** Configure Kafka Producer/Consumer processes with a custom schema registry. */ @Bean("duheSchemaRegistryConfig") - protected SchemaRegistryConfig duheSchemaRegistryConfig( + protected KafkaConfiguration.SerDeKeyValueConfig duheSchemaRegistryConfig( final ConfigurationProvider provider, final SchemaRegistryService schemaRegistryService) { - Map props = new HashMap<>(); + Map props = new HashMap<>(); KafkaConfiguration kafkaConfiguration = provider.getKafka(); props.put( @@ -67,7 +67,13 @@ protected SchemaRegistryConfig duheSchemaRegistryConfig( schemaRegistryService.getSchemaIdForTopic(mcpTopicName).get().toString())); log.info("DataHub System Update Registry"); - return new SchemaRegistryConfig( - MockSystemUpdateSerializer.class, MockSystemUpdateDeserializer.class, props); + return kafkaConfiguration.getSerde().getEvent().toBuilder() + .value( + KafkaConfiguration.SerDeProperties.builder() + .serializer(MockSystemUpdateSerializer.class.getName()) + .deserializer(MockSystemUpdateDeserializer.class.getName()) + .build()) + .properties(props) + .build(); } } From e45674852c4723298f0abf82bed7baf1ebf09c8a Mon Sep 17 00:00:00 2001 From: eunseokyang <54825838+eunseokyang@users.noreply.github.com> Date: Fri, 6 Sep 2024 00:32:36 +0900 Subject: [PATCH 19/34] fix(ingest/protobuf): Improve String Handling for Multilingual Support in Descriptions (#10975) Co-authored-by: happyprg --- .../java/datahub/protobuf/ProtobufUtils.java | 12 +----------- .../datahub/protobuf/ProtobufUtilsTest.java | 17 ++++++++++++++++- 2 files changed, 17 insertions(+), 12 deletions(-) diff --git a/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/ProtobufUtils.java b/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/ProtobufUtils.java index ef5bc52aaee7af..84205126243686 100644 --- a/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/ProtobufUtils.java +++ b/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/ProtobufUtils.java @@ -7,7 +7,6 @@ import com.linkedin.util.Pair; import java.lang.reflect.InvocationTargetException; import java.lang.reflect.Method; -import java.nio.charset.StandardCharsets; import java.util.Arrays; import java.util.HashMap; import java.util.LinkedList; @@ -22,8 +21,7 @@ public class ProtobufUtils { private ProtobufUtils() {} public static String collapseLocationComments(DescriptorProtos.SourceCodeInfo.Location location) { - String orig = - Stream.concat( + return Stream.concat( location.getLeadingDetachedCommentsList().stream(), Stream.of(location.getLeadingComments(), location.getTrailingComments())) .filter(Objects::nonNull) @@ -31,14 +29,6 @@ public static String collapseLocationComments(DescriptorProtos.SourceCodeInfo.Lo .map(line -> line.replaceFirst("^[*/ ]+", "")) .collect(Collectors.joining("\n")) .trim(); - - /* - * Sometimes DataHub doesn't like these strings. Not sure if its DataHub - * or protobuf issue: https://github.com/protocolbuffers/protobuf/issues/4691 - * - * We essentially smash utf8 chars to ascii here - */ - return new String(orig.getBytes(StandardCharsets.ISO_8859_1)); } /* diff --git a/metadata-integration/java/datahub-protobuf/src/test/java/datahub/protobuf/ProtobufUtilsTest.java b/metadata-integration/java/datahub-protobuf/src/test/java/datahub/protobuf/ProtobufUtilsTest.java index 9bf649041e035f..78a90048bca59a 100644 --- a/metadata-integration/java/datahub-protobuf/src/test/java/datahub/protobuf/ProtobufUtilsTest.java +++ b/metadata-integration/java/datahub-protobuf/src/test/java/datahub/protobuf/ProtobufUtilsTest.java @@ -8,6 +8,7 @@ import com.google.protobuf.ExtensionRegistry; import datahub.protobuf.model.ProtobufGraph; import java.io.IOException; +import java.util.Arrays; import org.testng.annotations.Test; public class ProtobufUtilsTest { @@ -44,4 +45,18 @@ public void registryTest() throws IOException, IllegalArgumentException { + "[meta.msg.repeat_enum]: EVENT\n", graph.root().messageProto().getOptions().toString()); } -} + + @Test + public void testCollapseLocationCommentsWithUTF8() { + DescriptorProtos.SourceCodeInfo.Location location = DescriptorProtos.SourceCodeInfo.Location.newBuilder() + .addAllLeadingDetachedComments(Arrays.asList("/* Emoji 😊 */", "/* Accented é */")) + .setLeadingComments("/* Chinese 你好 */\n// Russian Привет") + .setTrailingComments("// Korean 안녕") + .build(); + + String actual = ProtobufUtils.collapseLocationComments(location); + String expected = "Emoji 😊 */\nAccented é */\nChinese 你好 */\nRussian Привет\nKorean 안녕"; + + assertEquals(expected, actual); + } +} \ No newline at end of file From 59f9a4ba550aca2bc822eb07669397ce9f22952d Mon Sep 17 00:00:00 2001 From: eunseokyang <54825838+eunseokyang@users.noreply.github.com> Date: Fri, 6 Sep 2024 00:32:58 +0900 Subject: [PATCH 20/34] feat(ingest): Support protobuf description for enum field (#11027) MIME-Version: 1.0 Content-Type: text/plain; charset=UTF-8 Content-Transfer-Encoding: 8bit Co-authored-by: 양은석[G플레이스데이터개발] Co-authored-by: david-leifker <114954101+david-leifker@users.noreply.github.com> --- .../datahub/protobuf/model/ProtobufField.java | 361 ++++++++++-------- .../field/ProtobufExtensionFieldVisitor.java | 156 +++++--- .../protobuf/model/ProtobufFieldTest.java | 18 +- .../extended_protobuf/messageE.proto | 19 + .../extended_protobuf/messageE.protoc | Bin 0 -> 602 bytes 5 files changed, 334 insertions(+), 220 deletions(-) create mode 100644 metadata-integration/java/datahub-protobuf/src/test/resources/extended_protobuf/messageE.proto create mode 100644 metadata-integration/java/datahub-protobuf/src/test/resources/extended_protobuf/messageE.protoc diff --git a/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/model/ProtobufField.java b/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/model/ProtobufField.java index c3ede2e62c3148..836c036c4dc35d 100644 --- a/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/model/ProtobufField.java +++ b/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/model/ProtobufField.java @@ -1,5 +1,6 @@ package datahub.protobuf.model; +import com.google.protobuf.DescriptorProtos; import com.google.protobuf.DescriptorProtos.DescriptorProto; import com.google.protobuf.DescriptorProtos.FieldDescriptorProto; import com.google.protobuf.DescriptorProtos.FileDescriptorProto; @@ -18,14 +19,19 @@ import datahub.protobuf.ProtobufUtils; import datahub.protobuf.visitors.ProtobufModelVisitor; import datahub.protobuf.visitors.VisitContext; +import lombok.AllArgsConstructor; +import lombok.Builder; +import lombok.Getter; + import java.util.ArrayList; +import java.util.Collections; +import java.util.LinkedHashMap; import java.util.List; +import java.util.Map; import java.util.Optional; import java.util.stream.Collectors; import java.util.stream.Stream; -import lombok.AllArgsConstructor; -import lombok.Builder; -import lombok.Getter; + @Builder(toBuilder = true) @Getter @@ -81,78 +87,72 @@ public int getNumber() { @Override public String nativeType() { - return Optional.ofNullable(nativeType) - .orElseGet( - () -> { - if (fieldProto.getTypeName().isEmpty()) { - return fieldProto.getType().name().split("_")[1].toLowerCase(); - } else { - return fieldProto.getTypeName().replaceFirst("^[.]", ""); - } - }); + return Optional.ofNullable(nativeType).orElseGet(() -> { + if (fieldProto.getTypeName().isEmpty()) { + return fieldProto.getType().name().split("_")[1].toLowerCase(); + } else { + return fieldProto.getTypeName().replaceFirst("^[.]", ""); + } + }); } @Override public String fieldPathType() { - return Optional.ofNullable(fieldPathType) - .orElseGet( - () -> { - final String pathType; - - switch (fieldProto.getType()) { - case TYPE_DOUBLE: - pathType = "double"; - break; - case TYPE_FLOAT: - pathType = "float"; - break; - case TYPE_SFIXED64: - case TYPE_FIXED64: - case TYPE_UINT64: - case TYPE_INT64: - case TYPE_SINT64: - pathType = "long"; - break; - case TYPE_FIXED32: - case TYPE_SFIXED32: - case TYPE_INT32: - case TYPE_UINT32: - case TYPE_SINT32: - pathType = "int"; - break; - case TYPE_BYTES: - pathType = "bytes"; - break; - case TYPE_ENUM: - pathType = "enum"; - break; - case TYPE_BOOL: - pathType = "boolean"; - break; - case TYPE_STRING: - pathType = "string"; - break; - case TYPE_GROUP: - case TYPE_MESSAGE: - pathType = nativeType().replace(".", "_"); - break; - default: - throw new IllegalStateException( - String.format( - "Unexpected FieldDescriptorProto => FieldPathType %s", - fieldProto.getType())); - } - - StringArray fieldPath = new StringArray(); - - if (schemaFieldDataType().getType().isArrayType()) { - fieldPath.add("[type=array]"); - } - - fieldPath.add(String.format("[type=%s]", pathType)); - - return String.join(".", fieldPath); - }); + return Optional.ofNullable(fieldPathType).orElseGet(() -> { + final String pathType; + + switch (fieldProto.getType()) { + case TYPE_DOUBLE: + pathType = "double"; + break; + case TYPE_FLOAT: + pathType = "float"; + break; + case TYPE_SFIXED64: + case TYPE_FIXED64: + case TYPE_UINT64: + case TYPE_INT64: + case TYPE_SINT64: + pathType = "long"; + break; + case TYPE_FIXED32: + case TYPE_SFIXED32: + case TYPE_INT32: + case TYPE_UINT32: + case TYPE_SINT32: + pathType = "int"; + break; + case TYPE_BYTES: + pathType = "bytes"; + break; + case TYPE_ENUM: + pathType = "enum"; + break; + case TYPE_BOOL: + pathType = "boolean"; + break; + case TYPE_STRING: + pathType = "string"; + break; + case TYPE_GROUP: + case TYPE_MESSAGE: + pathType = nativeType().replace(".", "_"); + break; + default: + throw new IllegalStateException( + String.format("Unexpected FieldDescriptorProto => FieldPathType %s", fieldProto.getType())); + } + + StringArray fieldPath = new StringArray(); + + if (schemaFieldDataType().getType().isArrayType()) { + fieldPath.add("[type=array]"); + } + + fieldPath.add(String.format("[type=%s]", pathType)); + + return String.join(".", fieldPath); + }); } public boolean isMessage() { @@ -165,110 +165,92 @@ public int sortWeight() { } public SchemaFieldDataType schemaFieldDataType() throws IllegalStateException { - return Optional.ofNullable(schemaFieldDataType) - .orElseGet( - () -> { - final SchemaFieldDataType.Type fieldType; - - switch (fieldProto.getType()) { - case TYPE_DOUBLE: - case TYPE_FLOAT: - case TYPE_INT64: - case TYPE_UINT64: - case TYPE_INT32: - case TYPE_UINT32: - case TYPE_SINT32: - case TYPE_SINT64: - fieldType = SchemaFieldDataType.Type.create(new NumberType()); - break; - case TYPE_GROUP: - case TYPE_MESSAGE: - fieldType = SchemaFieldDataType.Type.create(new RecordType()); - break; - case TYPE_BYTES: - fieldType = SchemaFieldDataType.Type.create(new BytesType()); - break; - case TYPE_ENUM: - fieldType = SchemaFieldDataType.Type.create(new EnumType()); - break; - case TYPE_BOOL: - fieldType = SchemaFieldDataType.Type.create(new BooleanType()); - break; - case TYPE_STRING: - fieldType = SchemaFieldDataType.Type.create(new StringType()); - break; - case TYPE_FIXED64: - case TYPE_FIXED32: - case TYPE_SFIXED32: - case TYPE_SFIXED64: - fieldType = SchemaFieldDataType.Type.create(new FixedType()); - break; - default: - throw new IllegalStateException( - String.format( - "Unexpected FieldDescriptorProto => SchemaFieldDataType: %s", - fieldProto.getType())); - } - - if (fieldProto.getLabel().equals(FieldDescriptorProto.Label.LABEL_REPEATED)) { - return new SchemaFieldDataType() - .setType( - SchemaFieldDataType.Type.create( - new ArrayType().setNestedType(new StringArray()))); - } - - return new SchemaFieldDataType().setType(fieldType); - }); + return Optional.ofNullable(schemaFieldDataType).orElseGet(() -> { + final SchemaFieldDataType.Type fieldType; + + switch (fieldProto.getType()) { + case TYPE_DOUBLE: + case TYPE_FLOAT: + case TYPE_INT64: + case TYPE_UINT64: + case TYPE_INT32: + case TYPE_UINT32: + case TYPE_SINT32: + case TYPE_SINT64: + fieldType = SchemaFieldDataType.Type.create(new NumberType()); + break; + case TYPE_GROUP: + case TYPE_MESSAGE: + fieldType = SchemaFieldDataType.Type.create(new RecordType()); + break; + case TYPE_BYTES: + fieldType = SchemaFieldDataType.Type.create(new BytesType()); + break; + case TYPE_ENUM: + fieldType = SchemaFieldDataType.Type.create(new EnumType()); + break; + case TYPE_BOOL: + fieldType = SchemaFieldDataType.Type.create(new BooleanType()); + break; + case TYPE_STRING: + fieldType = SchemaFieldDataType.Type.create(new StringType()); + break; + case TYPE_FIXED64: + case TYPE_FIXED32: + case TYPE_SFIXED32: + case TYPE_SFIXED64: + fieldType = SchemaFieldDataType.Type.create(new FixedType()); + break; + default: + throw new IllegalStateException( + String.format("Unexpected FieldDescriptorProto => SchemaFieldDataType: %s", fieldProto.getType())); + } + + if (fieldProto.getLabel().equals(FieldDescriptorProto.Label.LABEL_REPEATED)) { + return new SchemaFieldDataType().setType( + SchemaFieldDataType.Type.create(new ArrayType().setNestedType(new StringArray()))); + } + + return new SchemaFieldDataType().setType(fieldType); + }); } @Override public Stream messageLocations() { List fileLocations = fileProto().getSourceCodeInfo().getLocationList(); return fileLocations.stream() - .filter( - loc -> - loc.getPathCount() > 1 - && loc.getPath(0) == FileDescriptorProto.MESSAGE_TYPE_FIELD_NUMBER); + .filter(loc -> loc.getPathCount() > 1 && loc.getPath(0) == FileDescriptorProto.MESSAGE_TYPE_FIELD_NUMBER); } @Override public String comment() { - return messageLocations() - .filter(location -> location.getPathCount() > 3) - .filter( - location -> - !ProtobufUtils.collapseLocationComments(location).isEmpty() - && !isEnumType(location.getPathList())) - .filter( - location -> { - List pathList = location.getPathList(); - DescriptorProto messageType = fileProto().getMessageType(pathList.get(1)); - - if (!isNestedType - && location.getPath(2) == DescriptorProto.FIELD_FIELD_NUMBER - && fieldProto == messageType.getField(location.getPath(3))) { - return true; - } else if (isNestedType - && location.getPath(2) == DescriptorProto.NESTED_TYPE_FIELD_NUMBER - && fieldProto == getNestedTypeFields(pathList, messageType)) { - return true; - } - return false; - }) + return messageLocations().filter(location -> location.getPathCount() > 3) + .filter(location -> !ProtobufUtils.collapseLocationComments(location).isEmpty() && !isEnumType( + location.getPathList())) + .filter(location -> { + List pathList = location.getPathList(); + DescriptorProto messageType = fileProto().getMessageType(pathList.get(1)); + + if (!isNestedType && location.getPath(2) == DescriptorProto.FIELD_FIELD_NUMBER + && fieldProto == messageType.getField(location.getPath(3))) { + return true; + } else if (isNestedType && location.getPath(2) == DescriptorProto.NESTED_TYPE_FIELD_NUMBER + && fieldProto == getNestedTypeFields(pathList, messageType)) { + return true; + } + return false; + }) .map(ProtobufUtils::collapseLocationComments) .collect(Collectors.joining("\n")) .trim(); } - private FieldDescriptorProto getNestedTypeFields( - List pathList, DescriptorProto messageType) { + private FieldDescriptorProto getNestedTypeFields(List pathList, DescriptorProto messageType) { int pathSize = pathList.size(); List nestedValues = new ArrayList<>(pathSize); for (int index = 0; index < pathSize; index++) { - if (index > 1 - && index % 2 == 0 - && pathList.get(index) == DescriptorProto.NESTED_TYPE_FIELD_NUMBER) { + if (index > 1 && index % 2 == 0 && pathList.get(index) == DescriptorProto.NESTED_TYPE_FIELD_NUMBER) { nestedValues.add(pathList.get(index + 1)); } } @@ -278,9 +260,7 @@ private FieldDescriptorProto getNestedTypeFields( } int fieldIndex = pathList.get(pathList.size() - 1); - if (isFieldPath(pathList) - && pathSize % 2 == 0 - && fieldIndex < messageType.getFieldList().size()) { + if (isFieldPath(pathList) && pathSize % 2 == 0 && fieldIndex < messageType.getFieldList().size()) { return messageType.getField(fieldIndex); } @@ -293,9 +273,7 @@ private boolean isFieldPath(List pathList) { private boolean isEnumType(List pathList) { for (int index = 0; index < pathList.size(); index++) { - if (index > 1 - && index % 2 == 0 - && pathList.get(index) == DescriptorProto.ENUM_TYPE_FIELD_NUMBER) { + if (index > 1 && index % 2 == 0 && pathList.get(index) == DescriptorProto.ENUM_TYPE_FIELD_NUMBER) { return true; } } @@ -330,4 +308,63 @@ public boolean equals(Object o) { public int hashCode() { return fullName().hashCode(); } + + public boolean isEnum() { + return getFieldProto().getType() == DescriptorProtos.FieldDescriptorProto.Type.TYPE_ENUM; + } + + public Optional getEnumDescriptor() { + if (!isEnum()) { + return Optional.empty(); + } + + String enumTypeName = getFieldProto().getTypeName(); + String shortEnumTypeName = enumTypeName.substring(enumTypeName.lastIndexOf('.') + 1); + + return getProtobufMessage().fileProto().getEnumTypeList().stream() + .filter(enumType -> enumType.getName().equals(shortEnumTypeName)) + .findFirst(); + } + + public List getEnumValues() { + return getEnumDescriptor().map(DescriptorProtos.EnumDescriptorProto::getValueList).orElse(Collections.emptyList()); + } + + public Map getEnumValuesWithComments() { + Optional enumProtoOpt = getEnumDescriptor(); + if (enumProtoOpt.isEmpty()) { + return Collections.emptyMap(); + } + + DescriptorProtos.EnumDescriptorProto enumProto = enumProtoOpt.get(); + Map valueComments = new LinkedHashMap<>(); + List values = enumProto.getValueList(); + List locations = + getProtobufMessage().fileProto().getSourceCodeInfo().getLocationList(); + + int enumIndex = getProtobufMessage().fileProto().getEnumTypeList().indexOf(enumProto); + + for (int i = 0; i < values.size(); i++) { + DescriptorProtos.EnumValueDescriptorProto value = values.get(i); + int finalI = i; + String comment = locations.stream() + .filter(loc -> isEnumValueLocation(loc, enumIndex, finalI)) + .findFirst() + .map(ProtobufUtils::collapseLocationComments) + .orElse(""); + + valueComments.put(value.getName(), comment); + } + + return valueComments; + } + + private boolean isEnumValueLocation(DescriptorProtos.SourceCodeInfo.Location location, int enumIndex, + int valueIndex) { + return location.getPathCount() > 3 + && location.getPath(0) == DescriptorProtos.FileDescriptorProto.ENUM_TYPE_FIELD_NUMBER + && location.getPath(1) == enumIndex + && location.getPath(2) == DescriptorProtos.EnumDescriptorProto.VALUE_FIELD_NUMBER + && location.getPath(3) == valueIndex; + } } diff --git a/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/visitors/field/ProtobufExtensionFieldVisitor.java b/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/visitors/field/ProtobufExtensionFieldVisitor.java index 240cf7b6d168b9..fb1df90b9c5b09 100644 --- a/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/visitors/field/ProtobufExtensionFieldVisitor.java +++ b/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/visitors/field/ProtobufExtensionFieldVisitor.java @@ -1,8 +1,5 @@ package datahub.protobuf.visitors.field; -import static datahub.protobuf.ProtobufUtils.getFieldOptions; -import static datahub.protobuf.ProtobufUtils.getMessageOptions; - import com.linkedin.common.GlobalTags; import com.linkedin.common.GlossaryTermAssociation; import com.linkedin.common.GlossaryTermAssociationArray; @@ -13,60 +10,107 @@ import com.linkedin.schema.SchemaField; import com.linkedin.tag.TagProperties; import com.linkedin.util.Pair; +import datahub.protobuf.model.FieldTypeEdge; +import datahub.protobuf.model.ProtobufElement; import datahub.protobuf.model.ProtobufField; import datahub.protobuf.visitors.ProtobufExtensionUtil; import datahub.protobuf.visitors.VisitContext; +import org.jgrapht.GraphPath; + import java.util.Comparator; import java.util.List; +import java.util.Map; import java.util.stream.Collectors; import java.util.stream.Stream; +import static datahub.protobuf.ProtobufUtils.getFieldOptions; +import static datahub.protobuf.ProtobufUtils.getMessageOptions; + + public class ProtobufExtensionFieldVisitor extends SchemaFieldVisitor { @Override public Stream> visitField(ProtobufField field, VisitContext context) { - boolean isPrimaryKey = - getFieldOptions(field.getFieldProto()).stream() - .map(Pair::getKey) - .anyMatch(fieldDesc -> fieldDesc.getName().matches("(?i).*primary_?key")); - - List tags = - Stream.concat( - ProtobufExtensionUtil.extractTagPropertiesFromOptions( - getFieldOptions(field.getFieldProto()), context.getGraph().getRegistry()), - promotedTags(field, context)) - .distinct() - .map(tag -> new TagAssociation().setTag(new TagUrn(tag.getName()))) - .sorted(Comparator.comparing(t -> t.getTag().getName())) - .collect(Collectors.toList()); - - List terms = - Stream.concat( - ProtobufExtensionUtil.extractTermAssociationsFromOptions( - getFieldOptions(field.getFieldProto()), context.getGraph().getRegistry()), - promotedTerms(field, context)) - .distinct() - .sorted(Comparator.comparing(a -> a.getUrn().getNameEntity())) - .collect(Collectors.toList()); - - return context - .streamAllPaths(field) - .map( - path -> - Pair.of( - new SchemaField() - .setFieldPath(context.getFieldPath(path)) - .setNullable(!isPrimaryKey) - .setIsPartOfKey(isPrimaryKey) - .setDescription(field.comment()) - .setNativeDataType(field.nativeType()) - .setType(field.schemaFieldDataType()) - .setGlobalTags(new GlobalTags().setTags(new TagAssociationArray(tags))) - .setGlossaryTerms( - new GlossaryTerms() - .setTerms(new GlossaryTermAssociationArray(terms)) - .setAuditStamp(context.getAuditStamp())), - context.calculateSortOrder(path, field))); + boolean isPrimaryKey = getFieldOptions(field.getFieldProto()).stream() + .map(Pair::getKey) + .anyMatch(fieldDesc -> fieldDesc.getName().matches("(?i).*primary_?key")); + + List tags = getTagAssociations(field, context); + List terms = getGlossaryTermAssociations(field, context); + + return context.streamAllPaths(field) + .map(path -> Pair.of(createSchemaField(field, context, path, isPrimaryKey, tags, terms), + context.calculateSortOrder(path, field))); + } + + private SchemaField createSchemaField(ProtobufField field, VisitContext context, + GraphPath path, boolean isPrimaryKey, List tags, + List terms) { + String description = createFieldDescription(field); + + return new SchemaField().setFieldPath(context.getFieldPath(path)) + .setNullable(!isPrimaryKey) + .setIsPartOfKey(isPrimaryKey) + .setDescription(description) + .setNativeDataType(field.nativeType()) + .setType(field.schemaFieldDataType()) + .setGlobalTags(new GlobalTags().setTags(new TagAssociationArray(tags))) + .setGlossaryTerms(new GlossaryTerms().setTerms(new GlossaryTermAssociationArray(terms)) + .setAuditStamp(context.getAuditStamp())); + } + + private String createFieldDescription(ProtobufField field) { + StringBuilder description = new StringBuilder(field.comment()); + + if (field.isEnum()) { + description.append("\n\n"); + Map enumValuesWithComments = field.getEnumValuesWithComments(); + if (!enumValuesWithComments.isEmpty()) { + appendEnumValues(description, field, enumValuesWithComments); + } + } + + return description.toString(); + } + + private void appendEnumValues(StringBuilder description, ProtobufField field, + Map enumValuesWithComments) { + enumValuesWithComments.forEach((name, comment) -> { + field.getEnumValues().stream().filter(v -> v.getName().equals(name)).findFirst().ifPresent(value -> { + description.append(String.format("%d: %s", value.getNumber(), name)); + if (!comment.isEmpty()) { + description.append(" - ").append(comment); + } + description.append("\n"); + }); + }); + } + + private List getTagAssociations(ProtobufField field, VisitContext context) { + Stream fieldTags = + ProtobufExtensionUtil.extractTagPropertiesFromOptions(getFieldOptions(field.getFieldProto()), + context.getGraph().getRegistry()).map(tag -> new TagAssociation().setTag(new TagUrn(tag.getName()))); + + Stream promotedTags = + promotedTags(field, context).map(tag -> new TagAssociation().setTag(new TagUrn(tag.getName()))); + + return Stream.concat(fieldTags, promotedTags) + .distinct() + .sorted(Comparator.comparing(t -> t.getTag().getName())) + .collect(Collectors.toList()); + } + + private List getGlossaryTermAssociations(ProtobufField field, VisitContext context) { + Stream fieldTerms = + ProtobufExtensionUtil.extractTermAssociationsFromOptions(getFieldOptions(field.getFieldProto()), + context.getGraph().getRegistry()); + + Stream promotedTerms = promotedTerms(field, context); + + return Stream.concat(fieldTerms, promotedTerms) + .distinct() + .sorted(Comparator.comparing(a -> a.getUrn().getNameEntity())) + .collect(Collectors.toList()); } /** @@ -76,12 +120,11 @@ public Stream> visitField(ProtobufField field, VisitCo */ private Stream promotedTags(ProtobufField field, VisitContext context) { if (field.isMessage()) { - return context.getGraph().outgoingEdgesOf(field).stream() - .flatMap( - e -> - ProtobufExtensionUtil.extractTagPropertiesFromOptions( - getMessageOptions(e.getEdgeTarget().messageProto()), - context.getGraph().getRegistry())) + return context.getGraph() + .outgoingEdgesOf(field) + .stream() + .flatMap(e -> ProtobufExtensionUtil.extractTagPropertiesFromOptions( + getMessageOptions(e.getEdgeTarget().messageProto()), context.getGraph().getRegistry())) .distinct(); } else { return Stream.of(); @@ -95,12 +138,11 @@ private Stream promotedTags(ProtobufField field, VisitContext con */ private Stream promotedTerms(ProtobufField field, VisitContext context) { if (field.isMessage()) { - return context.getGraph().outgoingEdgesOf(field).stream() - .flatMap( - e -> - ProtobufExtensionUtil.extractTermAssociationsFromOptions( - getMessageOptions(e.getEdgeTarget().messageProto()), - context.getGraph().getRegistry())) + return context.getGraph() + .outgoingEdgesOf(field) + .stream() + .flatMap(e -> ProtobufExtensionUtil.extractTermAssociationsFromOptions( + getMessageOptions(e.getEdgeTarget().messageProto()), context.getGraph().getRegistry())) .distinct(); } else { return Stream.of(); diff --git a/metadata-integration/java/datahub-protobuf/src/test/java/datahub/protobuf/model/ProtobufFieldTest.java b/metadata-integration/java/datahub-protobuf/src/test/java/datahub/protobuf/model/ProtobufFieldTest.java index 40d54a86510120..78f01e020111ff 100644 --- a/metadata-integration/java/datahub-protobuf/src/test/java/datahub/protobuf/model/ProtobufFieldTest.java +++ b/metadata-integration/java/datahub-protobuf/src/test/java/datahub/protobuf/model/ProtobufFieldTest.java @@ -355,4 +355,20 @@ public void nestedTypeReservedFieldsTest() throws IOException { assertEquals("test comment 14", msg3Field14.getDescription()); } -} + + @Test + public void timestampUnitEnumDescriptionTest() throws IOException { + ProtobufDataset test = getTestProtobufDataset("extended_protobuf", "messageE"); + SchemaMetadata testMetadata = test.getSchemaMetadata(); + + SchemaField timestampField = testMetadata.getFields() + .stream() + .filter(v -> v.getFieldPath() + .equals("[version=2.0].[type=extended_protobuf_TimestampUnitMessage].[type=enum].timestamp_unit_type")) + .findFirst() + .orElseThrow(); + + assertEquals("timestamp unit\n" + "\n" + "0: MILLISECOND - 10^-3 seconds\n" + "1: MICROSECOND - 10^-6 seconds\n" + + "2: NANOSECOND - 10^-9 seconds\n", timestampField.getDescription()); + } +} \ No newline at end of file diff --git a/metadata-integration/java/datahub-protobuf/src/test/resources/extended_protobuf/messageE.proto b/metadata-integration/java/datahub-protobuf/src/test/resources/extended_protobuf/messageE.proto new file mode 100644 index 00000000000000..50425f431c62d0 --- /dev/null +++ b/metadata-integration/java/datahub-protobuf/src/test/resources/extended_protobuf/messageE.proto @@ -0,0 +1,19 @@ +syntax = "proto3"; +package extended_protobuf; + +/* + Timestamp unit enum +*/ +enum TimestampUnitEnum { + MILLISECOND = 0; // 10^-3 seconds + MICROSECOND = 1; // 10^-6 seconds + NANOSECOND = 2; // 10^-9 seconds +} + +/* + Timestamp unit message +*/ +message TimestampUnitMessage { + // timestamp unit + TimestampUnitEnum timestamp_unit_type = 1; +} \ No newline at end of file diff --git a/metadata-integration/java/datahub-protobuf/src/test/resources/extended_protobuf/messageE.protoc b/metadata-integration/java/datahub-protobuf/src/test/resources/extended_protobuf/messageE.protoc new file mode 100644 index 0000000000000000000000000000000000000000..1cefa365ef178550d2d5cdbc7b83a11a94994190 GIT binary patch literal 602 zcmZWn+fKqj5Z&EwOBs=N7c`{7q!JSiDp5&Hd^Fex43`A)RRXda61l{dM8DJ@@dKPK zZ4;qSd*;lUGiSH(!=X4=VK{zQL1Xo~jFwWUuShMXYC4MXWc^nAfbwvLZP9qXdS1+; z?nWVpP>Ry}XpO`u`d+CD_32sh=A^MRsPS(~uvpIrA{(Fw4^dtZKErvgY{LS1*@MKUA;F#WVycfT>yR&9VIyp;68ii4rM0 zQ{HYXX-ua|y`r5d5#*UjJny!Z43&9SNIaQtc3e0C#xb0O;l0Xsxa7U#d|dDB*i|?J p&f|Q7U3jjay-Iu^aX?L5(h#hq%``%(D4(XtKvX}USn*%e`~!73ckuuK literal 0 HcmV?d00001 From 35d134b981b4a88783b7da10d0911798d6f771a1 Mon Sep 17 00:00:00 2001 From: siladitya <68184387+siladitya2@users.noreply.github.com> Date: Thu, 5 Sep 2024 18:42:24 +0200 Subject: [PATCH 21/34] fix(search): Search not returning result if query text contains forward slash (#10932) Co-authored-by: si-chakraborty Co-authored-by: david-leifker <114954101+david-leifker@users.noreply.github.com> --- datahub-frontend/app/utils/SearchUtil.java | 2 +- datahub-frontend/test/utils/SearchUtilTest.java | 4 ++-- .../com/linkedin/datahub/graphql/resolvers/ResolverUtils.java | 2 +- 3 files changed, 4 insertions(+), 4 deletions(-) diff --git a/datahub-frontend/app/utils/SearchUtil.java b/datahub-frontend/app/utils/SearchUtil.java index 803c70a63646a0..cfbf11c2ffa85a 100644 --- a/datahub-frontend/app/utils/SearchUtil.java +++ b/datahub-frontend/app/utils/SearchUtil.java @@ -20,7 +20,7 @@ private SearchUtil() { @Nonnull public static String escapeForwardSlash(@Nonnull String input) { if (input.contains("/")) { - input = input.replace("/", "\\\\/"); + input = input.replace("/", "\\/"); } return input; } diff --git a/datahub-frontend/test/utils/SearchUtilTest.java b/datahub-frontend/test/utils/SearchUtilTest.java index 6767fa56374692..2efc4420c7f766 100644 --- a/datahub-frontend/test/utils/SearchUtilTest.java +++ b/datahub-frontend/test/utils/SearchUtilTest.java @@ -8,10 +8,10 @@ public class SearchUtilTest { @Test public void testEscapeForwardSlash() { // escape "/" - assertEquals("\\\\/foo\\\\/bar", SearchUtil.escapeForwardSlash("/foo/bar")); + assertEquals("\\/foo\\/bar", SearchUtil.escapeForwardSlash("/foo/bar")); // "/" is escaped but "*" is not escaped and is treated as regex. Since currently we want to // retain the regex behaviour with "*" - assertEquals("\\\\/foo\\\\/bar\\\\/*", SearchUtil.escapeForwardSlash("/foo/bar/*")); + assertEquals("\\/foo\\/bar\\/*", SearchUtil.escapeForwardSlash("/foo/bar/*")); assertEquals("", ""); assertEquals("foo", "foo"); } diff --git a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/ResolverUtils.java b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/ResolverUtils.java index 346b353da93e47..d34fd9f32d322e 100644 --- a/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/ResolverUtils.java +++ b/datahub-graphql-core/src/main/java/com/linkedin/datahub/graphql/resolvers/ResolverUtils.java @@ -70,7 +70,7 @@ public static T bindArgument(Object argument, Class clazz) { @Nonnull public static String escapeForwardSlash(@Nonnull String input) { if (input.contains("/")) { - input = input.replace("/", "\\\\/"); + input = input.replace("/", "\\/"); } return input; } From d788cd753c101025bbfef7358267d5ec395cd19d Mon Sep 17 00:00:00 2001 From: Mayuri Nehate <33225191+mayurinehate@users.noreply.github.com> Date: Thu, 5 Sep 2024 22:17:26 +0530 Subject: [PATCH 22/34] feat(ingest/salesforce): helpful error messages on failure (#11266) --- .../datahub/ingestion/source/salesforce.py | 72 +++++++++++++------ 1 file changed, 52 insertions(+), 20 deletions(-) diff --git a/metadata-ingestion/src/datahub/ingestion/source/salesforce.py b/metadata-ingestion/src/datahub/ingestion/source/salesforce.py index 7a7f1f30950eb6..88679efdf5fc31 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/salesforce.py +++ b/metadata-ingestion/src/datahub/ingestion/source/salesforce.py @@ -8,6 +8,7 @@ import requests from pydantic import Field, validator from simple_salesforce import Salesforce +from simple_salesforce.exceptions import SalesforceAuthenticationFailed import datahub.emitter.mce_builder as builder from datahub.configuration.common import ( @@ -285,9 +286,20 @@ def __init__(self, config: SalesforceConfig, ctx: PipelineContext) -> None: **common_args, ) - except Exception as e: + except SalesforceAuthenticationFailed as e: logger.error(e) - raise ConfigurationError("Salesforce login failed") from e + if "API_CURRENTLY_DISABLED" in str(e): + # https://help.salesforce.com/s/articleView?id=001473830&type=1 + error = "Salesforce login failed. Please make sure user has API Enabled Access." + else: + error = "Salesforce login failed. Please verify your credentials." + if ( + self.config.instance_url + and "sandbox" in self.config.instance_url.lower() + ): + error += "Please set `is_sandbox: True` in recipe if this is sandbox account." + raise ConfigurationError(error) from e + if not self.config.api_version: # List all REST API versions and use latest one versions_url = "https://{instance}/services/data/".format( @@ -314,10 +326,19 @@ def __init__(self, config: SalesforceConfig, ctx: PipelineContext) -> None: ) def get_workunits_internal(self) -> Iterable[MetadataWorkUnit]: - sObjects = self.get_salesforce_objects() - - for sObject in sObjects: - yield from self.get_salesforce_object_workunits(sObject) + try: + sObjects = self.get_salesforce_objects() + except Exception as e: + if "sObject type 'EntityDefinition' is not supported." in str(e): + # https://developer.salesforce.com/docs/atlas.en-us.api_tooling.meta/api_tooling/tooling_api_objects_entitydefinition.htm + raise ConfigurationError( + "Salesforce EntityDefinition query failed. " + "Please verify if user has 'View Setup and Configuration' permission." + ) from e + raise e + else: + for sObject in sObjects: + yield from self.get_salesforce_object_workunits(sObject) def get_salesforce_object_workunits( self, sObject: dict @@ -596,9 +617,9 @@ def _get_schema_field( TypeClass = FIELD_TYPE_MAPPING.get(fieldType) if TypeClass is None: - self.report.report_warning( - sObjectName, - f"Unable to map type {fieldType} to metadata schema", + self.report.warning( + message="Unable to map field type to metadata schema", + context=f"{fieldType} for {fieldName} of {sObjectName}", ) TypeClass = NullTypeClass @@ -696,19 +717,30 @@ def get_schema_metadata_workunit( ) ) - sObject_custom_fields_response = self.sf._call_salesforce( - "GET", sObject_custom_fields_query_url - ).json() + customFields: Dict[str, Dict] = {} + try: + sObject_custom_fields_response = self.sf._call_salesforce( + "GET", sObject_custom_fields_query_url + ).json() - logger.debug( - "Received Salesforce {sObject} custom fields response".format( - sObject=sObjectName + logger.debug( + "Received Salesforce {sObject} custom fields response".format( + sObject=sObjectName + ) ) - ) - customFields: Dict[str, Dict] = { - record["DeveloperName"]: record - for record in sObject_custom_fields_response["records"] - } + + except Exception as e: + error = "Salesforce CustomField query failed. " + if "sObject type 'CustomField' is not supported." in str(e): + # https://github.com/afawcett/apex-toolingapi/issues/19 + error += "Please verify if user has 'View All Data' permission." + + self.report.warning(message=error, exc=e) + else: + customFields = { + record["DeveloperName"]: record + for record in sObject_custom_fields_response["records"] + } fields: List[SchemaFieldClass] = [] primaryKeys: List[str] = [] From d795a5357d1a9d32bcb8cd3efef559f2462c46a0 Mon Sep 17 00:00:00 2001 From: david-leifker <114954101+david-leifker@users.noreply.github.com> Date: Thu, 5 Sep 2024 14:09:13 -0500 Subject: [PATCH 23/34] fix(search): fix regression from #10932 (#11309) --- .../java/datahub/protobuf/ProtobufUtils.java | 14 +- .../datahub/protobuf/model/ProtobufField.java | 317 ++++++++++-------- .../field/ProtobufExtensionFieldVisitor.java | 108 +++--- .../datahub/protobuf/ProtobufUtilsTest.java | 13 +- .../protobuf/model/ProtobufFieldTest.java | 28 +- .../query/request/SearchQueryBuilder.java | 2 +- 6 files changed, 270 insertions(+), 212 deletions(-) diff --git a/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/ProtobufUtils.java b/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/ProtobufUtils.java index 84205126243686..c19b98f1780435 100644 --- a/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/ProtobufUtils.java +++ b/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/ProtobufUtils.java @@ -22,13 +22,13 @@ private ProtobufUtils() {} public static String collapseLocationComments(DescriptorProtos.SourceCodeInfo.Location location) { return Stream.concat( - location.getLeadingDetachedCommentsList().stream(), - Stream.of(location.getLeadingComments(), location.getTrailingComments())) - .filter(Objects::nonNull) - .flatMap(line -> Arrays.stream(line.split("\n"))) - .map(line -> line.replaceFirst("^[*/ ]+", "")) - .collect(Collectors.joining("\n")) - .trim(); + location.getLeadingDetachedCommentsList().stream(), + Stream.of(location.getLeadingComments(), location.getTrailingComments())) + .filter(Objects::nonNull) + .flatMap(line -> Arrays.stream(line.split("\n"))) + .map(line -> line.replaceFirst("^[*/ ]+", "")) + .collect(Collectors.joining("\n")) + .trim(); } /* diff --git a/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/model/ProtobufField.java b/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/model/ProtobufField.java index 836c036c4dc35d..88cde57fd9f8e2 100644 --- a/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/model/ProtobufField.java +++ b/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/model/ProtobufField.java @@ -19,10 +19,6 @@ import datahub.protobuf.ProtobufUtils; import datahub.protobuf.visitors.ProtobufModelVisitor; import datahub.protobuf.visitors.VisitContext; -import lombok.AllArgsConstructor; -import lombok.Builder; -import lombok.Getter; - import java.util.ArrayList; import java.util.Collections; import java.util.LinkedHashMap; @@ -31,7 +27,9 @@ import java.util.Optional; import java.util.stream.Collectors; import java.util.stream.Stream; - +import lombok.AllArgsConstructor; +import lombok.Builder; +import lombok.Getter; @Builder(toBuilder = true) @Getter @@ -87,72 +85,78 @@ public int getNumber() { @Override public String nativeType() { - return Optional.ofNullable(nativeType).orElseGet(() -> { - if (fieldProto.getTypeName().isEmpty()) { - return fieldProto.getType().name().split("_")[1].toLowerCase(); - } else { - return fieldProto.getTypeName().replaceFirst("^[.]", ""); - } - }); + return Optional.ofNullable(nativeType) + .orElseGet( + () -> { + if (fieldProto.getTypeName().isEmpty()) { + return fieldProto.getType().name().split("_")[1].toLowerCase(); + } else { + return fieldProto.getTypeName().replaceFirst("^[.]", ""); + } + }); } @Override public String fieldPathType() { - return Optional.ofNullable(fieldPathType).orElseGet(() -> { - final String pathType; - - switch (fieldProto.getType()) { - case TYPE_DOUBLE: - pathType = "double"; - break; - case TYPE_FLOAT: - pathType = "float"; - break; - case TYPE_SFIXED64: - case TYPE_FIXED64: - case TYPE_UINT64: - case TYPE_INT64: - case TYPE_SINT64: - pathType = "long"; - break; - case TYPE_FIXED32: - case TYPE_SFIXED32: - case TYPE_INT32: - case TYPE_UINT32: - case TYPE_SINT32: - pathType = "int"; - break; - case TYPE_BYTES: - pathType = "bytes"; - break; - case TYPE_ENUM: - pathType = "enum"; - break; - case TYPE_BOOL: - pathType = "boolean"; - break; - case TYPE_STRING: - pathType = "string"; - break; - case TYPE_GROUP: - case TYPE_MESSAGE: - pathType = nativeType().replace(".", "_"); - break; - default: - throw new IllegalStateException( - String.format("Unexpected FieldDescriptorProto => FieldPathType %s", fieldProto.getType())); - } - - StringArray fieldPath = new StringArray(); - - if (schemaFieldDataType().getType().isArrayType()) { - fieldPath.add("[type=array]"); - } - - fieldPath.add(String.format("[type=%s]", pathType)); - - return String.join(".", fieldPath); - }); + return Optional.ofNullable(fieldPathType) + .orElseGet( + () -> { + final String pathType; + + switch (fieldProto.getType()) { + case TYPE_DOUBLE: + pathType = "double"; + break; + case TYPE_FLOAT: + pathType = "float"; + break; + case TYPE_SFIXED64: + case TYPE_FIXED64: + case TYPE_UINT64: + case TYPE_INT64: + case TYPE_SINT64: + pathType = "long"; + break; + case TYPE_FIXED32: + case TYPE_SFIXED32: + case TYPE_INT32: + case TYPE_UINT32: + case TYPE_SINT32: + pathType = "int"; + break; + case TYPE_BYTES: + pathType = "bytes"; + break; + case TYPE_ENUM: + pathType = "enum"; + break; + case TYPE_BOOL: + pathType = "boolean"; + break; + case TYPE_STRING: + pathType = "string"; + break; + case TYPE_GROUP: + case TYPE_MESSAGE: + pathType = nativeType().replace(".", "_"); + break; + default: + throw new IllegalStateException( + String.format( + "Unexpected FieldDescriptorProto => FieldPathType %s", + fieldProto.getType())); + } + + StringArray fieldPath = new StringArray(); + + if (schemaFieldDataType().getType().isArrayType()) { + fieldPath.add("[type=array]"); + } + + fieldPath.add(String.format("[type=%s]", pathType)); + + return String.join(".", fieldPath); + }); } public boolean isMessage() { @@ -165,92 +169,110 @@ public int sortWeight() { } public SchemaFieldDataType schemaFieldDataType() throws IllegalStateException { - return Optional.ofNullable(schemaFieldDataType).orElseGet(() -> { - final SchemaFieldDataType.Type fieldType; - - switch (fieldProto.getType()) { - case TYPE_DOUBLE: - case TYPE_FLOAT: - case TYPE_INT64: - case TYPE_UINT64: - case TYPE_INT32: - case TYPE_UINT32: - case TYPE_SINT32: - case TYPE_SINT64: - fieldType = SchemaFieldDataType.Type.create(new NumberType()); - break; - case TYPE_GROUP: - case TYPE_MESSAGE: - fieldType = SchemaFieldDataType.Type.create(new RecordType()); - break; - case TYPE_BYTES: - fieldType = SchemaFieldDataType.Type.create(new BytesType()); - break; - case TYPE_ENUM: - fieldType = SchemaFieldDataType.Type.create(new EnumType()); - break; - case TYPE_BOOL: - fieldType = SchemaFieldDataType.Type.create(new BooleanType()); - break; - case TYPE_STRING: - fieldType = SchemaFieldDataType.Type.create(new StringType()); - break; - case TYPE_FIXED64: - case TYPE_FIXED32: - case TYPE_SFIXED32: - case TYPE_SFIXED64: - fieldType = SchemaFieldDataType.Type.create(new FixedType()); - break; - default: - throw new IllegalStateException( - String.format("Unexpected FieldDescriptorProto => SchemaFieldDataType: %s", fieldProto.getType())); - } - - if (fieldProto.getLabel().equals(FieldDescriptorProto.Label.LABEL_REPEATED)) { - return new SchemaFieldDataType().setType( - SchemaFieldDataType.Type.create(new ArrayType().setNestedType(new StringArray()))); - } - - return new SchemaFieldDataType().setType(fieldType); - }); + return Optional.ofNullable(schemaFieldDataType) + .orElseGet( + () -> { + final SchemaFieldDataType.Type fieldType; + + switch (fieldProto.getType()) { + case TYPE_DOUBLE: + case TYPE_FLOAT: + case TYPE_INT64: + case TYPE_UINT64: + case TYPE_INT32: + case TYPE_UINT32: + case TYPE_SINT32: + case TYPE_SINT64: + fieldType = SchemaFieldDataType.Type.create(new NumberType()); + break; + case TYPE_GROUP: + case TYPE_MESSAGE: + fieldType = SchemaFieldDataType.Type.create(new RecordType()); + break; + case TYPE_BYTES: + fieldType = SchemaFieldDataType.Type.create(new BytesType()); + break; + case TYPE_ENUM: + fieldType = SchemaFieldDataType.Type.create(new EnumType()); + break; + case TYPE_BOOL: + fieldType = SchemaFieldDataType.Type.create(new BooleanType()); + break; + case TYPE_STRING: + fieldType = SchemaFieldDataType.Type.create(new StringType()); + break; + case TYPE_FIXED64: + case TYPE_FIXED32: + case TYPE_SFIXED32: + case TYPE_SFIXED64: + fieldType = SchemaFieldDataType.Type.create(new FixedType()); + break; + default: + throw new IllegalStateException( + String.format( + "Unexpected FieldDescriptorProto => SchemaFieldDataType: %s", + fieldProto.getType())); + } + + if (fieldProto.getLabel().equals(FieldDescriptorProto.Label.LABEL_REPEATED)) { + return new SchemaFieldDataType() + .setType( + SchemaFieldDataType.Type.create( + new ArrayType().setNestedType(new StringArray()))); + } + + return new SchemaFieldDataType().setType(fieldType); + }); } @Override public Stream messageLocations() { List fileLocations = fileProto().getSourceCodeInfo().getLocationList(); return fileLocations.stream() - .filter(loc -> loc.getPathCount() > 1 && loc.getPath(0) == FileDescriptorProto.MESSAGE_TYPE_FIELD_NUMBER); + .filter( + loc -> + loc.getPathCount() > 1 + && loc.getPath(0) == FileDescriptorProto.MESSAGE_TYPE_FIELD_NUMBER); } @Override public String comment() { - return messageLocations().filter(location -> location.getPathCount() > 3) - .filter(location -> !ProtobufUtils.collapseLocationComments(location).isEmpty() && !isEnumType( - location.getPathList())) - .filter(location -> { - List pathList = location.getPathList(); - DescriptorProto messageType = fileProto().getMessageType(pathList.get(1)); - - if (!isNestedType && location.getPath(2) == DescriptorProto.FIELD_FIELD_NUMBER - && fieldProto == messageType.getField(location.getPath(3))) { - return true; - } else if (isNestedType && location.getPath(2) == DescriptorProto.NESTED_TYPE_FIELD_NUMBER - && fieldProto == getNestedTypeFields(pathList, messageType)) { - return true; - } - return false; - }) + return messageLocations() + .filter(location -> location.getPathCount() > 3) + .filter( + location -> + !ProtobufUtils.collapseLocationComments(location).isEmpty() + && !isEnumType(location.getPathList())) + .filter( + location -> { + List pathList = location.getPathList(); + DescriptorProto messageType = fileProto().getMessageType(pathList.get(1)); + + if (!isNestedType + && location.getPath(2) == DescriptorProto.FIELD_FIELD_NUMBER + && fieldProto == messageType.getField(location.getPath(3))) { + return true; + } else if (isNestedType + && location.getPath(2) == DescriptorProto.NESTED_TYPE_FIELD_NUMBER + && fieldProto == getNestedTypeFields(pathList, messageType)) { + return true; + } + return false; + }) .map(ProtobufUtils::collapseLocationComments) .collect(Collectors.joining("\n")) .trim(); } - private FieldDescriptorProto getNestedTypeFields(List pathList, DescriptorProto messageType) { + private FieldDescriptorProto getNestedTypeFields( + List pathList, DescriptorProto messageType) { int pathSize = pathList.size(); List nestedValues = new ArrayList<>(pathSize); for (int index = 0; index < pathSize; index++) { - if (index > 1 && index % 2 == 0 && pathList.get(index) == DescriptorProto.NESTED_TYPE_FIELD_NUMBER) { + if (index > 1 + && index % 2 == 0 + && pathList.get(index) == DescriptorProto.NESTED_TYPE_FIELD_NUMBER) { nestedValues.add(pathList.get(index + 1)); } } @@ -260,7 +282,9 @@ private FieldDescriptorProto getNestedTypeFields(List pathList, Descrip } int fieldIndex = pathList.get(pathList.size() - 1); - if (isFieldPath(pathList) && pathSize % 2 == 0 && fieldIndex < messageType.getFieldList().size()) { + if (isFieldPath(pathList) + && pathSize % 2 == 0 + && fieldIndex < messageType.getFieldList().size()) { return messageType.getField(fieldIndex); } @@ -273,7 +297,9 @@ private boolean isFieldPath(List pathList) { private boolean isEnumType(List pathList) { for (int index = 0; index < pathList.size(); index++) { - if (index > 1 && index % 2 == 0 && pathList.get(index) == DescriptorProto.ENUM_TYPE_FIELD_NUMBER) { + if (index > 1 + && index % 2 == 0 + && pathList.get(index) == DescriptorProto.ENUM_TYPE_FIELD_NUMBER) { return true; } } @@ -327,7 +353,9 @@ public Optional getEnumDescriptor() { } public List getEnumValues() { - return getEnumDescriptor().map(DescriptorProtos.EnumDescriptorProto::getValueList).orElse(Collections.emptyList()); + return getEnumDescriptor() + .map(DescriptorProtos.EnumDescriptorProto::getValueList) + .orElse(Collections.emptyList()); } public Map getEnumValuesWithComments() { @@ -347,11 +375,12 @@ public Map getEnumValuesWithComments() { for (int i = 0; i < values.size(); i++) { DescriptorProtos.EnumValueDescriptorProto value = values.get(i); int finalI = i; - String comment = locations.stream() - .filter(loc -> isEnumValueLocation(loc, enumIndex, finalI)) - .findFirst() - .map(ProtobufUtils::collapseLocationComments) - .orElse(""); + String comment = + locations.stream() + .filter(loc -> isEnumValueLocation(loc, enumIndex, finalI)) + .findFirst() + .map(ProtobufUtils::collapseLocationComments) + .orElse(""); valueComments.put(value.getName(), comment); } @@ -359,8 +388,8 @@ public Map getEnumValuesWithComments() { return valueComments; } - private boolean isEnumValueLocation(DescriptorProtos.SourceCodeInfo.Location location, int enumIndex, - int valueIndex) { + private boolean isEnumValueLocation( + DescriptorProtos.SourceCodeInfo.Location location, int enumIndex, int valueIndex) { return location.getPathCount() > 3 && location.getPath(0) == DescriptorProtos.FileDescriptorProto.ENUM_TYPE_FIELD_NUMBER && location.getPath(1) == enumIndex diff --git a/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/visitors/field/ProtobufExtensionFieldVisitor.java b/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/visitors/field/ProtobufExtensionFieldVisitor.java index fb1df90b9c5b09..2919d0d37defac 100644 --- a/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/visitors/field/ProtobufExtensionFieldVisitor.java +++ b/metadata-integration/java/datahub-protobuf/src/main/java/datahub/protobuf/visitors/field/ProtobufExtensionFieldVisitor.java @@ -1,5 +1,8 @@ package datahub.protobuf.visitors.field; +import static datahub.protobuf.ProtobufUtils.getFieldOptions; +import static datahub.protobuf.ProtobufUtils.getMessageOptions; + import com.linkedin.common.GlobalTags; import com.linkedin.common.GlossaryTermAssociation; import com.linkedin.common.GlossaryTermAssociationArray; @@ -15,48 +18,55 @@ import datahub.protobuf.model.ProtobufField; import datahub.protobuf.visitors.ProtobufExtensionUtil; import datahub.protobuf.visitors.VisitContext; -import org.jgrapht.GraphPath; - import java.util.Comparator; import java.util.List; import java.util.Map; import java.util.stream.Collectors; import java.util.stream.Stream; - -import static datahub.protobuf.ProtobufUtils.getFieldOptions; -import static datahub.protobuf.ProtobufUtils.getMessageOptions; - +import org.jgrapht.GraphPath; public class ProtobufExtensionFieldVisitor extends SchemaFieldVisitor { @Override public Stream> visitField(ProtobufField field, VisitContext context) { - boolean isPrimaryKey = getFieldOptions(field.getFieldProto()).stream() - .map(Pair::getKey) - .anyMatch(fieldDesc -> fieldDesc.getName().matches("(?i).*primary_?key")); + boolean isPrimaryKey = + getFieldOptions(field.getFieldProto()).stream() + .map(Pair::getKey) + .anyMatch(fieldDesc -> fieldDesc.getName().matches("(?i).*primary_?key")); List tags = getTagAssociations(field, context); List terms = getGlossaryTermAssociations(field, context); - return context.streamAllPaths(field) - .map(path -> Pair.of(createSchemaField(field, context, path, isPrimaryKey, tags, terms), - context.calculateSortOrder(path, field))); + return context + .streamAllPaths(field) + .map( + path -> + Pair.of( + createSchemaField(field, context, path, isPrimaryKey, tags, terms), + context.calculateSortOrder(path, field))); } - private SchemaField createSchemaField(ProtobufField field, VisitContext context, - GraphPath path, boolean isPrimaryKey, List tags, + private SchemaField createSchemaField( + ProtobufField field, + VisitContext context, + GraphPath path, + boolean isPrimaryKey, + List tags, List terms) { String description = createFieldDescription(field); - return new SchemaField().setFieldPath(context.getFieldPath(path)) + return new SchemaField() + .setFieldPath(context.getFieldPath(path)) .setNullable(!isPrimaryKey) .setIsPartOfKey(isPrimaryKey) .setDescription(description) .setNativeDataType(field.nativeType()) .setType(field.schemaFieldDataType()) .setGlobalTags(new GlobalTags().setTags(new TagAssociationArray(tags))) - .setGlossaryTerms(new GlossaryTerms().setTerms(new GlossaryTermAssociationArray(terms)) - .setAuditStamp(context.getAuditStamp())); + .setGlossaryTerms( + new GlossaryTerms() + .setTerms(new GlossaryTermAssociationArray(terms)) + .setAuditStamp(context.getAuditStamp())); } private String createFieldDescription(ProtobufField field) { @@ -73,26 +83,33 @@ private String createFieldDescription(ProtobufField field) { return description.toString(); } - private void appendEnumValues(StringBuilder description, ProtobufField field, - Map enumValuesWithComments) { - enumValuesWithComments.forEach((name, comment) -> { - field.getEnumValues().stream().filter(v -> v.getName().equals(name)).findFirst().ifPresent(value -> { - description.append(String.format("%d: %s", value.getNumber(), name)); - if (!comment.isEmpty()) { - description.append(" - ").append(comment); - } - description.append("\n"); - }); - }); + private void appendEnumValues( + StringBuilder description, ProtobufField field, Map enumValuesWithComments) { + enumValuesWithComments.forEach( + (name, comment) -> { + field.getEnumValues().stream() + .filter(v -> v.getName().equals(name)) + .findFirst() + .ifPresent( + value -> { + description.append(String.format("%d: %s", value.getNumber(), name)); + if (!comment.isEmpty()) { + description.append(" - ").append(comment); + } + description.append("\n"); + }); + }); } private List getTagAssociations(ProtobufField field, VisitContext context) { Stream fieldTags = - ProtobufExtensionUtil.extractTagPropertiesFromOptions(getFieldOptions(field.getFieldProto()), - context.getGraph().getRegistry()).map(tag -> new TagAssociation().setTag(new TagUrn(tag.getName()))); + ProtobufExtensionUtil.extractTagPropertiesFromOptions( + getFieldOptions(field.getFieldProto()), context.getGraph().getRegistry()) + .map(tag -> new TagAssociation().setTag(new TagUrn(tag.getName()))); Stream promotedTags = - promotedTags(field, context).map(tag -> new TagAssociation().setTag(new TagUrn(tag.getName()))); + promotedTags(field, context) + .map(tag -> new TagAssociation().setTag(new TagUrn(tag.getName()))); return Stream.concat(fieldTags, promotedTags) .distinct() @@ -100,10 +117,11 @@ private List getTagAssociations(ProtobufField field, VisitContex .collect(Collectors.toList()); } - private List getGlossaryTermAssociations(ProtobufField field, VisitContext context) { + private List getGlossaryTermAssociations( + ProtobufField field, VisitContext context) { Stream fieldTerms = - ProtobufExtensionUtil.extractTermAssociationsFromOptions(getFieldOptions(field.getFieldProto()), - context.getGraph().getRegistry()); + ProtobufExtensionUtil.extractTermAssociationsFromOptions( + getFieldOptions(field.getFieldProto()), context.getGraph().getRegistry()); Stream promotedTerms = promotedTerms(field, context); @@ -120,11 +138,12 @@ private List getGlossaryTermAssociations(ProtobufField */ private Stream promotedTags(ProtobufField field, VisitContext context) { if (field.isMessage()) { - return context.getGraph() - .outgoingEdgesOf(field) - .stream() - .flatMap(e -> ProtobufExtensionUtil.extractTagPropertiesFromOptions( - getMessageOptions(e.getEdgeTarget().messageProto()), context.getGraph().getRegistry())) + return context.getGraph().outgoingEdgesOf(field).stream() + .flatMap( + e -> + ProtobufExtensionUtil.extractTagPropertiesFromOptions( + getMessageOptions(e.getEdgeTarget().messageProto()), + context.getGraph().getRegistry())) .distinct(); } else { return Stream.of(); @@ -138,11 +157,12 @@ private Stream promotedTags(ProtobufField field, VisitContext con */ private Stream promotedTerms(ProtobufField field, VisitContext context) { if (field.isMessage()) { - return context.getGraph() - .outgoingEdgesOf(field) - .stream() - .flatMap(e -> ProtobufExtensionUtil.extractTermAssociationsFromOptions( - getMessageOptions(e.getEdgeTarget().messageProto()), context.getGraph().getRegistry())) + return context.getGraph().outgoingEdgesOf(field).stream() + .flatMap( + e -> + ProtobufExtensionUtil.extractTermAssociationsFromOptions( + getMessageOptions(e.getEdgeTarget().messageProto()), + context.getGraph().getRegistry())) .distinct(); } else { return Stream.of(); diff --git a/metadata-integration/java/datahub-protobuf/src/test/java/datahub/protobuf/ProtobufUtilsTest.java b/metadata-integration/java/datahub-protobuf/src/test/java/datahub/protobuf/ProtobufUtilsTest.java index 78a90048bca59a..92ec4629f2eb31 100644 --- a/metadata-integration/java/datahub-protobuf/src/test/java/datahub/protobuf/ProtobufUtilsTest.java +++ b/metadata-integration/java/datahub-protobuf/src/test/java/datahub/protobuf/ProtobufUtilsTest.java @@ -48,15 +48,16 @@ public void registryTest() throws IOException, IllegalArgumentException { @Test public void testCollapseLocationCommentsWithUTF8() { - DescriptorProtos.SourceCodeInfo.Location location = DescriptorProtos.SourceCodeInfo.Location.newBuilder() - .addAllLeadingDetachedComments(Arrays.asList("/* Emoji 😊 */", "/* Accented é */")) - .setLeadingComments("/* Chinese 你好 */\n// Russian Привет") - .setTrailingComments("// Korean 안녕") - .build(); + DescriptorProtos.SourceCodeInfo.Location location = + DescriptorProtos.SourceCodeInfo.Location.newBuilder() + .addAllLeadingDetachedComments(Arrays.asList("/* Emoji 😊 */", "/* Accented é */")) + .setLeadingComments("/* Chinese 你好 */\n// Russian Привет") + .setTrailingComments("// Korean 안녕") + .build(); String actual = ProtobufUtils.collapseLocationComments(location); String expected = "Emoji 😊 */\nAccented é */\nChinese 你好 */\nRussian Привет\nKorean 안녕"; assertEquals(expected, actual); } -} \ No newline at end of file +} diff --git a/metadata-integration/java/datahub-protobuf/src/test/java/datahub/protobuf/model/ProtobufFieldTest.java b/metadata-integration/java/datahub-protobuf/src/test/java/datahub/protobuf/model/ProtobufFieldTest.java index 78f01e020111ff..4c19e34d710b4d 100644 --- a/metadata-integration/java/datahub-protobuf/src/test/java/datahub/protobuf/model/ProtobufFieldTest.java +++ b/metadata-integration/java/datahub-protobuf/src/test/java/datahub/protobuf/model/ProtobufFieldTest.java @@ -361,14 +361,22 @@ public void timestampUnitEnumDescriptionTest() throws IOException { ProtobufDataset test = getTestProtobufDataset("extended_protobuf", "messageE"); SchemaMetadata testMetadata = test.getSchemaMetadata(); - SchemaField timestampField = testMetadata.getFields() - .stream() - .filter(v -> v.getFieldPath() - .equals("[version=2.0].[type=extended_protobuf_TimestampUnitMessage].[type=enum].timestamp_unit_type")) - .findFirst() - .orElseThrow(); - - assertEquals("timestamp unit\n" + "\n" + "0: MILLISECOND - 10^-3 seconds\n" + "1: MICROSECOND - 10^-6 seconds\n" - + "2: NANOSECOND - 10^-9 seconds\n", timestampField.getDescription()); + SchemaField timestampField = + testMetadata.getFields().stream() + .filter( + v -> + v.getFieldPath() + .equals( + "[version=2.0].[type=extended_protobuf_TimestampUnitMessage].[type=enum].timestamp_unit_type")) + .findFirst() + .orElseThrow(); + + assertEquals( + "timestamp unit\n" + + "\n" + + "0: MILLISECOND - 10^-3 seconds\n" + + "1: MICROSECOND - 10^-6 seconds\n" + + "2: NANOSECOND - 10^-9 seconds\n", + timestampField.getDescription()); } -} \ No newline at end of file +} diff --git a/metadata-io/src/main/java/com/linkedin/metadata/search/elasticsearch/query/request/SearchQueryBuilder.java b/metadata-io/src/main/java/com/linkedin/metadata/search/elasticsearch/query/request/SearchQueryBuilder.java index 6a1f24a92e4a3a..9ac460ed7e1e1d 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/search/elasticsearch/query/request/SearchQueryBuilder.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/search/elasticsearch/query/request/SearchQueryBuilder.java @@ -52,7 +52,7 @@ @Slf4j public class SearchQueryBuilder { - public static final String STRUCTURED_QUERY_PREFIX = "\\\\/q "; + public static final String STRUCTURED_QUERY_PREFIX = "\\/q "; private final ExactMatchConfiguration exactMatchConfiguration; private final PartialConfiguration partialConfiguration; private final WordGramConfiguration wordGramConfiguration; From a146ffa32d5c76173aed0009063043bb3f842d39 Mon Sep 17 00:00:00 2001 From: Pinaki Bhattacharjee Date: Fri, 6 Sep 2024 01:06:12 +0530 Subject: [PATCH 24/34] chore(vulnerability): Insecure randomness (#11058) Co-authored-by: david-leifker <114954101+david-leifker@users.noreply.github.com> --- .../tests/cypress/cypress/e2e/mutations/dataset_ownership.js | 2 +- .../tests/cypress/cypress/e2e/mutations/ingestion_source.js | 2 +- .../tests/cypress/cypress/e2e/mutations/managing_secrets.js | 2 +- .../tests/cypress/cypress/e2e/settings/managing_groups.js | 2 +- 4 files changed, 4 insertions(+), 4 deletions(-) diff --git a/smoke-test/tests/cypress/cypress/e2e/mutations/dataset_ownership.js b/smoke-test/tests/cypress/cypress/e2e/mutations/dataset_ownership.js index 452e2eb3408d31..9c42d8395e543c 100644 --- a/smoke-test/tests/cypress/cypress/e2e/mutations/dataset_ownership.js +++ b/smoke-test/tests/cypress/cypress/e2e/mutations/dataset_ownership.js @@ -1,4 +1,4 @@ -const test_id = Math.floor(Math.random() * 100000); +const test_id = crypto.getRandomValues(new Uint32Array(1))[0]; const username = `Example Name ${test_id}`; const email = `example${test_id}@example.com`; const password = "Example password"; diff --git a/smoke-test/tests/cypress/cypress/e2e/mutations/ingestion_source.js b/smoke-test/tests/cypress/cypress/e2e/mutations/ingestion_source.js index 95c63835902e8a..9ed3ccdd26eeef 100644 --- a/smoke-test/tests/cypress/cypress/e2e/mutations/ingestion_source.js +++ b/smoke-test/tests/cypress/cypress/e2e/mutations/ingestion_source.js @@ -1,4 +1,4 @@ -const number = Math.floor(Math.random() * 100000); +const number = crypto.getRandomValues(new Uint32Array(1))[0]; const accound_id = `account${number}`; const warehouse_id = `warehouse${number}`; const username = `user${number}`; diff --git a/smoke-test/tests/cypress/cypress/e2e/mutations/managing_secrets.js b/smoke-test/tests/cypress/cypress/e2e/mutations/managing_secrets.js index 5a2b101ddd8bb7..d35ed883f58848 100644 --- a/smoke-test/tests/cypress/cypress/e2e/mutations/managing_secrets.js +++ b/smoke-test/tests/cypress/cypress/e2e/mutations/managing_secrets.js @@ -1,4 +1,4 @@ -const number = Math.floor(Math.random() * 100000); +const number = crypto.getRandomValues(new Uint32Array(1))[0]; const accound_id = `account${number}`; const warehouse_id = `warehouse${number}`; const username = `user${number}`; diff --git a/smoke-test/tests/cypress/cypress/e2e/settings/managing_groups.js b/smoke-test/tests/cypress/cypress/e2e/settings/managing_groups.js index 247a9c8b9b2739..9a86f7e966e315 100644 --- a/smoke-test/tests/cypress/cypress/e2e/settings/managing_groups.js +++ b/smoke-test/tests/cypress/cypress/e2e/settings/managing_groups.js @@ -1,4 +1,4 @@ -const test_id = Math.floor(Math.random() * 100000); +const test_id = crypto.getRandomValues(new Uint32Array(1))[0]; const username = `Example Name ${test_id}`; const email = `example${test_id}@example.com`; const password = "Example password"; From c3a7850a1111ed2ee5d482bb80599282c5cc2c0f Mon Sep 17 00:00:00 2001 From: Rohan Sunkari <66036924+rohansun@users.noreply.github.com> Date: Thu, 5 Sep 2024 16:26:11 -0400 Subject: [PATCH 25/34] feat(ingest/sql): add default dialect support to SqlQueriesSource (#11285) --- .../src/datahub/ingestion/source/sql_queries.py | 5 +++++ 1 file changed, 5 insertions(+) diff --git a/metadata-ingestion/src/datahub/ingestion/source/sql_queries.py b/metadata-ingestion/src/datahub/ingestion/source/sql_queries.py index 138430a68fcb9d..f3e8e774e4388f 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/sql_queries.py +++ b/metadata-ingestion/src/datahub/ingestion/source/sql_queries.py @@ -66,6 +66,10 @@ class SqlQueriesSourceConfig(PlatformInstanceConfigMixin, EnvConfigMixin): description="The default schema to use for unqualified table names", default=None, ) + default_dialect: Optional[str] = Field( + description="The SQL dialect to use when parsing queries. Overrides automatic dialect detection.", + default=None, + ) class SqlQueriesSourceReport(SourceReport): @@ -177,6 +181,7 @@ def _process_query(self, entry: "QueryEntry") -> Iterable[MetadataWorkUnit]: schema_resolver=self.schema_resolver, default_db=self.config.default_db, default_schema=self.config.default_schema, + default_dialect=self.config.default_dialect, ) if result.debug_info.table_error: logger.info(f"Error parsing table lineage, {result.debug_info.table_error}") From 455c90fdcb83651019a5e5681958e4ceb2204d20 Mon Sep 17 00:00:00 2001 From: Nbagga14 <114913591+Nbagga14@users.noreply.github.com> Date: Fri, 6 Sep 2024 20:40:41 +0530 Subject: [PATCH 26/34] fix : added support for multiple values for CONTAIN, START_WITH and END_WITH operators (#11068) --- .../metadata/search/utils/ESUtils.java | 96 +++++++-- .../metadata/search/utils/ESUtilsTest.java | 191 ++++++++++++++++++ 2 files changed, 275 insertions(+), 12 deletions(-) diff --git a/metadata-io/src/main/java/com/linkedin/metadata/search/utils/ESUtils.java b/metadata-io/src/main/java/com/linkedin/metadata/search/utils/ESUtils.java index c4060bbb0928b2..6c9b339af42c7b 100644 --- a/metadata-io/src/main/java/com/linkedin/metadata/search/utils/ESUtils.java +++ b/metadata-io/src/main/java/com/linkedin/metadata/search/utils/ESUtils.java @@ -555,25 +555,97 @@ private static QueryBuilder getQueryBuilderFromCriterionForSingleField( aspectRetriever) .queryName(queryName != null ? queryName : fieldName); } else if (condition == Condition.CONTAIN) { - return QueryBuilders.wildcardQuery( - toKeywordField(criterion.getField(), isTimeseries, aspectRetriever), - "*" + ESUtils.escapeReservedCharacters(criterion.getValue().trim()) + "*") - .queryName(queryName != null ? queryName : fieldName); + return buildContainsConditionFromCriterion( + fieldName, criterion, queryName, isTimeseries, aspectRetriever); } else if (condition == Condition.START_WITH) { - return QueryBuilders.wildcardQuery( - toKeywordField(criterion.getField(), isTimeseries, aspectRetriever), - ESUtils.escapeReservedCharacters(criterion.getValue().trim()) + "*") - .queryName(queryName != null ? queryName : fieldName); + return buildStartsWithConditionFromCriterion( + fieldName, criterion, queryName, isTimeseries, aspectRetriever); } else if (condition == Condition.END_WITH) { - return QueryBuilders.wildcardQuery( - toKeywordField(criterion.getField(), isTimeseries, aspectRetriever), - "*" + ESUtils.escapeReservedCharacters(criterion.getValue().trim())) - .queryName(queryName != null ? queryName : fieldName); + return buildEndsWithConditionFromCriterion( + fieldName, criterion, queryName, isTimeseries, aspectRetriever); } } throw new UnsupportedOperationException("Unsupported condition: " + condition); } + private static QueryBuilder buildWildcardQueryWithMultipleValues( + @Nonnull final String fieldName, + @Nonnull final Criterion criterion, + final boolean isTimeseries, + @Nullable String queryName, + @Nonnull AspectRetriever aspectRetriever, + String wildcardPattern) { + BoolQueryBuilder boolQuery = QueryBuilders.boolQuery(); + + for (String value : criterion.getValues()) { + boolQuery.should( + QueryBuilders.wildcardQuery( + toKeywordField(criterion.getField(), isTimeseries, aspectRetriever), + String.format(wildcardPattern, ESUtils.escapeReservedCharacters(value.trim()))) + .queryName(queryName != null ? queryName : fieldName)); + } + return boolQuery; + } + + private static QueryBuilder buildWildcardQueryWithSingleValue( + @Nonnull final String fieldName, + @Nonnull final Criterion criterion, + final boolean isTimeseries, + @Nullable String queryName, + @Nonnull AspectRetriever aspectRetriever, + String wildcardPattern) { + return QueryBuilders.wildcardQuery( + toKeywordField(criterion.getField(), isTimeseries, aspectRetriever), + String.format( + wildcardPattern, ESUtils.escapeReservedCharacters(criterion.getValue().trim()))) + .queryName(queryName != null ? queryName : fieldName); + } + + private static QueryBuilder buildContainsConditionFromCriterion( + @Nonnull final String fieldName, + @Nonnull final Criterion criterion, + @Nullable String queryName, + final boolean isTimeseries, + @Nonnull AspectRetriever aspectRetriever) { + + if (!criterion.getValues().isEmpty()) { + return buildWildcardQueryWithMultipleValues( + fieldName, criterion, isTimeseries, queryName, aspectRetriever, "*%s*"); + } + return buildWildcardQueryWithSingleValue( + fieldName, criterion, isTimeseries, queryName, aspectRetriever, "*%s*"); + } + + private static QueryBuilder buildStartsWithConditionFromCriterion( + @Nonnull final String fieldName, + @Nonnull final Criterion criterion, + @Nullable String queryName, + final boolean isTimeseries, + @Nonnull AspectRetriever aspectRetriever) { + + if (!criterion.getValues().isEmpty()) { + return buildWildcardQueryWithMultipleValues( + fieldName, criterion, isTimeseries, queryName, aspectRetriever, "%s*"); + } + return buildWildcardQueryWithSingleValue( + fieldName, criterion, isTimeseries, queryName, aspectRetriever, "%s*"); + } + + private static QueryBuilder buildEndsWithConditionFromCriterion( + @Nonnull final String fieldName, + @Nonnull final Criterion criterion, + @Nullable String queryName, + final boolean isTimeseries, + @Nonnull AspectRetriever aspectRetriever) { + + if (!criterion.getValues().isEmpty()) { + return buildWildcardQueryWithMultipleValues( + fieldName, criterion, isTimeseries, queryName, aspectRetriever, "*%s"); + } + return buildWildcardQueryWithSingleValue( + fieldName, criterion, isTimeseries, queryName, aspectRetriever, "*%s"); + } + private static QueryBuilder buildEqualsConditionFromCriterion( @Nonnull final String fieldName, @Nonnull final Criterion criterion, diff --git a/metadata-io/src/test/java/com/linkedin/metadata/search/utils/ESUtilsTest.java b/metadata-io/src/test/java/com/linkedin/metadata/search/utils/ESUtilsTest.java index d56d9b0674884f..bbc494159a498f 100644 --- a/metadata-io/src/test/java/com/linkedin/metadata/search/utils/ESUtilsTest.java +++ b/metadata-io/src/test/java/com/linkedin/metadata/search/utils/ESUtilsTest.java @@ -145,6 +145,197 @@ public void testGetQueryBuilderFromCriterionEqualsValues() { Assert.assertEquals(result.toString(), expected); } + @Test + public void testGetQueryBuilderFromCriterionContain() { + final Criterion singleValueCriterion = + new Criterion().setField("myTestField").setCondition(Condition.CONTAIN).setValue("value1"); + + QueryBuilder result = + ESUtils.getQueryBuilderFromCriterion( + singleValueCriterion, false, new HashMap<>(), mock(AspectRetriever.class)); + + String expected = + "{\n" + + " \"wildcard\" : {\n" + + " \"myTestField.keyword\" : {\n" + + " \"wildcard\" : \"*value1*\",\n" + + " \"boost\" : 1.0,\n" + + " \"_name\" : \"myTestField\"\n" + + " }\n" + + " }\n" + + "}"; + + Assert.assertEquals(result.toString(), expected); + + final Criterion multiValueCriterion = + new Criterion() + .setField("myTestField") + .setCondition(Condition.CONTAIN) + .setValues(new StringArray(ImmutableList.of("value1", "value2"))); + + result = + ESUtils.getQueryBuilderFromCriterion( + multiValueCriterion, false, new HashMap<>(), mock(AspectRetriever.class)); + + expected = + "{\n" + + " \"bool\" : {\n" + + " \"should\" : [\n" + + " {\n" + + " \"wildcard\" : {\n" + + " \"myTestField.keyword\" : {\n" + + " \"wildcard\" : \"*value1*\",\n" + + " \"boost\" : 1.0,\n" + + " \"_name\" : \"myTestField\"\n" + + " }\n" + + " }\n" + + " },\n" + + " {\n" + + " \"wildcard\" : {\n" + + " \"myTestField.keyword\" : {\n" + + " \"wildcard\" : \"*value2*\",\n" + + " \"boost\" : 1.0,\n" + + " \"_name\" : \"myTestField\"\n" + + " }\n" + + " }\n" + + " }\n" + + " ],\n" + + " \"adjust_pure_negative\" : true,\n" + + " \"boost\" : 1.0\n" + + " }\n" + + "}"; + + Assert.assertEquals(result.toString(), expected); + } + + @Test + public void testWildcardQueryBuilderFromCriterionWhenStartsWith() { + final Criterion singleValueCriterion = + new Criterion() + .setField("myTestField") + .setCondition(Condition.START_WITH) + .setValue("value1"); + + QueryBuilder result = + ESUtils.getQueryBuilderFromCriterion( + singleValueCriterion, false, new HashMap<>(), mock(AspectRetriever.class)); + + String expected = + "{\n" + + " \"wildcard\" : {\n" + + " \"myTestField.keyword\" : {\n" + + " \"wildcard\" : \"value1*\",\n" + + " \"boost\" : 1.0,\n" + + " \"_name\" : \"myTestField\"\n" + + " }\n" + + " }\n" + + "}"; + + Assert.assertEquals(result.toString(), expected); + + final Criterion multiValueCriterion = + new Criterion() + .setField("myTestField") + .setCondition(Condition.START_WITH) + .setValues(new StringArray(ImmutableList.of("value1", "value2"))); + + result = + ESUtils.getQueryBuilderFromCriterion( + multiValueCriterion, false, new HashMap<>(), mock(AspectRetriever.class)); + + expected = + "{\n" + + " \"bool\" : {\n" + + " \"should\" : [\n" + + " {\n" + + " \"wildcard\" : {\n" + + " \"myTestField.keyword\" : {\n" + + " \"wildcard\" : \"value1*\",\n" + + " \"boost\" : 1.0,\n" + + " \"_name\" : \"myTestField\"\n" + + " }\n" + + " }\n" + + " },\n" + + " {\n" + + " \"wildcard\" : {\n" + + " \"myTestField.keyword\" : {\n" + + " \"wildcard\" : \"value2*\",\n" + + " \"boost\" : 1.0,\n" + + " \"_name\" : \"myTestField\"\n" + + " }\n" + + " }\n" + + " }\n" + + " ],\n" + + " \"adjust_pure_negative\" : true,\n" + + " \"boost\" : 1.0\n" + + " }\n" + + "}"; + + Assert.assertEquals(result.toString(), expected); + } + + @Test + public void testWildcardQueryBuilderFromCriterionWhenEndsWith() { + final Criterion singleValueCriterion = + new Criterion().setField("myTestField").setCondition(Condition.END_WITH).setValue("value1"); + + QueryBuilder result = + ESUtils.getQueryBuilderFromCriterion( + singleValueCriterion, false, new HashMap<>(), mock(AspectRetriever.class)); + + String expected = + "{\n" + + " \"wildcard\" : {\n" + + " \"myTestField.keyword\" : {\n" + + " \"wildcard\" : \"*value1\",\n" + + " \"boost\" : 1.0,\n" + + " \"_name\" : \"myTestField\"\n" + + " }\n" + + " }\n" + + "}"; + Assert.assertEquals(result.toString(), expected); + + final Criterion multiValueCriterion = + new Criterion() + .setField("myTestField") + .setCondition(Condition.END_WITH) + .setValues(new StringArray(ImmutableList.of("value1", "value2"))); + + result = + ESUtils.getQueryBuilderFromCriterion( + multiValueCriterion, false, new HashMap<>(), mock(AspectRetriever.class)); + + expected = + "{\n" + + " \"bool\" : {\n" + + " \"should\" : [\n" + + " {\n" + + " \"wildcard\" : {\n" + + " \"myTestField.keyword\" : {\n" + + " \"wildcard\" : \"*value1\",\n" + + " \"boost\" : 1.0,\n" + + " \"_name\" : \"myTestField\"\n" + + " }\n" + + " }\n" + + " },\n" + + " {\n" + + " \"wildcard\" : {\n" + + " \"myTestField.keyword\" : {\n" + + " \"wildcard\" : \"*value2\",\n" + + " \"boost\" : 1.0,\n" + + " \"_name\" : \"myTestField\"\n" + + " }\n" + + " }\n" + + " }\n" + + " ],\n" + + " \"adjust_pure_negative\" : true,\n" + + " \"boost\" : 1.0\n" + + " }\n" + + "}"; + + Assert.assertEquals(result.toString(), expected); + } + @Test public void testGetQueryBuilderFromCriterionExists() { final Criterion singleValueCriterion = From 9589adebb36684125b93a7c9cd50473f768e3db3 Mon Sep 17 00:00:00 2001 From: Harshal Sheth Date: Fri, 6 Sep 2024 10:02:40 -0700 Subject: [PATCH 27/34] feat(ingest): enable query usage stats by default (#11281) --- metadata-ingestion/setup.cfg | 2 +- .../source/bigquery_v2/queries_extractor.py | 2 +- .../source/snowflake/snowflake_queries.py | 19 +- .../source/snowflake/snowflake_v2.py | 1 + .../sql_parsing/sql_parsing_aggregator.py | 16 +- .../bigquery_queries_mcps_golden.json | 7582 ++++++++++++++++- .../bigquery_v2/test_bigquery_queries.py | 22 +- 7 files changed, 7297 insertions(+), 347 deletions(-) diff --git a/metadata-ingestion/setup.cfg b/metadata-ingestion/setup.cfg index 16af43abe3be73..c095420e4e3f30 100644 --- a/metadata-ingestion/setup.cfg +++ b/metadata-ingestion/setup.cfg @@ -78,7 +78,7 @@ disallow_untyped_defs = yes [tool:pytest] asyncio_mode = auto -addopts = --cov=src --cov-report= --cov-config setup.cfg --strict-markers +addopts = --cov=src --cov-report= --cov-config setup.cfg --strict-markers -p no:faker markers = slow: marks tests that are slow to run, including all docker-based tests (deselect with '-m not slow') integration: marks all integration tests, across all batches (deselect with '-m "not integration"') diff --git a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/queries_extractor.py b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/queries_extractor.py index 8e1d27847f2b68..2719d8b95bea83 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/queries_extractor.py +++ b/metadata-ingestion/src/datahub/ingestion/source/bigquery_v2/queries_extractor.py @@ -103,7 +103,7 @@ class BigQueryQueriesExtractorConfig(BigQueryBaseConfig): include_lineage: bool = True include_queries: bool = True include_usage_statistics: bool = True - include_query_usage_statistics: bool = False + include_query_usage_statistics: bool = True include_operations: bool = True region_qualifiers: List[str] = Field( diff --git a/metadata-ingestion/src/datahub/ingestion/source/snowflake/snowflake_queries.py b/metadata-ingestion/src/datahub/ingestion/source/snowflake/snowflake_queries.py index f03d687ac32f66..1445d02aa49dbd 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/snowflake/snowflake_queries.py +++ b/metadata-ingestion/src/datahub/ingestion/source/snowflake/snowflake_queries.py @@ -12,7 +12,7 @@ import pydantic from typing_extensions import Self -from datahub.configuration.common import ConfigModel +from datahub.configuration.common import AllowDenyPattern, ConfigModel from datahub.configuration.time_window_config import ( BaseTimeWindowConfig, BucketDuration, @@ -67,8 +67,16 @@ class SnowflakeQueriesExtractorConfig(ConfigModel): # TODO: Support stateful ingestion for the time windows. window: BaseTimeWindowConfig = BaseTimeWindowConfig() - # TODO: make this a proper allow/deny pattern - deny_usernames: List[str] = [] + pushdown_deny_usernames: List[str] = pydantic.Field( + default=[], + description="List of snowflake usernames which will not be considered for lineage/usage/queries extraction. " + "This is primarily useful for improving performance by filtering out users with extremely high query volumes.", + ) + + user_email_pattern: AllowDenyPattern = pydantic.Field( + default=AllowDenyPattern.allow_all(), + description="Regex patterns for user emails to filter in usage.", + ) temporary_tables_pattern: List[str] = pydantic.Field( default=DEFAULT_TEMP_TABLES_PATTERNS, @@ -88,7 +96,7 @@ class SnowflakeQueriesExtractorConfig(ConfigModel): include_lineage: bool = True include_queries: bool = True include_usage_statistics: bool = True - include_query_usage_statistics: bool = False + include_query_usage_statistics: bool = True include_operations: bool = True @@ -150,6 +158,7 @@ def __init__( bucket_duration=self.config.window.bucket_duration, start_time=self.config.window.start_time, end_time=self.config.window.end_time, + user_email_pattern=self.config.user_email_pattern, # TODO make the rest of the fields configurable ), generate_operations=self.config.include_operations, @@ -281,7 +290,7 @@ def fetch_query_log( start_time=self.config.window.start_time, end_time=self.config.window.end_time, bucket_duration=self.config.window.bucket_duration, - deny_usernames=self.config.deny_usernames, + deny_usernames=self.config.pushdown_deny_usernames, ) with self.structured_reporter.report_exc( diff --git a/metadata-ingestion/src/datahub/ingestion/source/snowflake/snowflake_v2.py b/metadata-ingestion/src/datahub/ingestion/source/snowflake/snowflake_v2.py index 4da232518cde2d..0d7881f36554d1 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/snowflake/snowflake_v2.py +++ b/metadata-ingestion/src/datahub/ingestion/source/snowflake/snowflake_v2.py @@ -521,6 +521,7 @@ def get_workunits_internal(self) -> Iterable[MetadataWorkUnit]: include_lineage=self.config.include_table_lineage, include_usage_statistics=self.config.include_usage_stats, include_operations=self.config.include_operational_stats, + user_email_pattern=self.config.user_email_pattern, ), structured_report=self.report, filters=self.filters, diff --git a/metadata-ingestion/src/datahub/sql_parsing/sql_parsing_aggregator.py b/metadata-ingestion/src/datahub/sql_parsing/sql_parsing_aggregator.py index 29204c58fa4b9a..9308ca8a0edd59 100644 --- a/metadata-ingestion/src/datahub/sql_parsing/sql_parsing_aggregator.py +++ b/metadata-ingestion/src/datahub/sql_parsing/sql_parsing_aggregator.py @@ -242,6 +242,7 @@ class SqlAggregatorReport(Report): # Usage-related. usage_skipped_missing_timestamp: int = 0 num_query_usage_stats_generated: int = 0 + num_query_usage_stats_outside_window: int = 0 # Operation-related. num_operations_generated: int = 0 @@ -432,6 +433,7 @@ def _need_schemas(self) -> bool: or self.generate_usage_statistics or self.generate_queries or self.generate_operations + or self.generate_query_usage_statistics ) def register_schema( @@ -1033,9 +1035,9 @@ def gen_metadata(self) -> Iterable[MetadataChangeProposalWrapper]: queries_generated: Set[QueryId] = set() yield from self._gen_lineage_mcps(queries_generated) - yield from self._gen_remaining_queries(queries_generated) yield from self._gen_usage_statistics_mcps() yield from self._gen_operation_mcps(queries_generated) + yield from self._gen_remaining_queries(queries_generated) def _gen_lineage_mcps( self, queries_generated: Set[QueryId] @@ -1322,9 +1324,15 @@ def _gen_query( query_counter = self._query_usage_counts.get(query_id) if not query_counter: return - for bucket in self.usage_config.buckets(): - count = query_counter.get(bucket) - if not count: + + all_buckets = self.usage_config.buckets() + + for bucket, count in query_counter.items(): + if bucket not in all_buckets: + # What happens if we get a query with a timestamp that's outside our configured window? + # Theoretically this should never happen, since the audit logs are also fetched + # for the window. However, it's useful to have reporting for it, just in case. + self.report.num_query_usage_stats_outside_window += 1 continue yield MetadataChangeProposalWrapper( diff --git a/metadata-ingestion/tests/integration/bigquery_v2/bigquery_queries_mcps_golden.json b/metadata-ingestion/tests/integration/bigquery_v2/bigquery_queries_mcps_golden.json index 2f12848ddfc695..a2d21b84f19e8c 100644 --- a/metadata-ingestion/tests/integration/bigquery_v2/bigquery_queries_mcps_golden.json +++ b/metadata-ingestion/tests/integration/bigquery_v2/bigquery_queries_mcps_golden.json @@ -103,6 +103,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:88c4674d369ef49e881a5ea67ed3485e48f09b9a4924d5282c3ae25004737f95", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "query", "entityUrn": "urn:li:query:88c4674d369ef49e881a5ea67ed3485e48f09b9a4924d5282c3ae25004737f95", @@ -200,6 +232,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6e250c6966754a5e6532fbb444172dacf5813b0b7afceefbf7772a29878f48f8", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "query", "entityUrn": "urn:li:query:6e250c6966754a5e6532fbb444172dacf5813b0b7afceefbf7772a29878f48f8", @@ -327,6 +391,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:49b267d0cd050c6a45b4d26bcdc6d9ddceb51aa7ed29399c52ef967e8da2b58d", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "query", "entityUrn": "urn:li:query:composite_0db44e02f671b69df68565346e9d2b68c7166fccf75bd494f34560bfa16c381b", @@ -426,6 +522,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:2fa44cc9d306c7523477fad59ff43e2e580081ee770da69b9b9f66e119b4dcab", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "query", "entityUrn": "urn:li:query:630f9169072a11dfd8d08a44479f2466acdf2dc2b078b946a739db437b74ad1d", @@ -579,6 +707,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6684f16158660588d874f7ac46dbd7e56ad42acfb95b8a3d1f01292de8dcb930", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "query", "entityUrn": "urn:li:query:44c19e1fccfa56779f6958f62d3476819b48af701bbee43ccecf5c9e04d63fc4", @@ -657,6 +817,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:44c19e1fccfa56779f6958f62d3476819b48af701bbee43ccecf5c9e04d63fc4", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "query", "entityUrn": "urn:li:query:b9c1cbdddc1018284bdfb113865f5dc95b5c5a106c8e1dad1297bc9ef70debf1", @@ -815,6 +1007,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:a049f27174fa88a7a7b1b7d5f60d2c353f3e9dd3d4994a8e35c91adb986eac4d", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "query", "entityUrn": "urn:li:query:2fa44cc9d306c7523477fad59ff43e2e580081ee770da69b9b9f66e119b4dcab", @@ -870,6 +1094,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:8f7bb4efb71d494b2bfe115937d6022db0ab9e6ea3d293839a457480e75430e1", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "dataset", "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD)", @@ -1089,14 +1345,78 @@ }, { "entityType": "query", - "entityUrn": "urn:li:query:5efacf0ddad8fd852ba394b29e7a4654ea454915930fb8dd4882c6f294b95cf8", + "entityUrn": "urn:li:query:e1769381f2d261efecb105f3ab6fc8a2fc6717a1509cc65ba125c03841b0923d", "changeType": "UPSERT", - "aspectName": "querySubjects", + "aspectName": "queryUsageStatistics", "aspect": { "json": { - "subjects": [ + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ { - "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.base_table_2,PROD)" + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:5efacf0ddad8fd852ba394b29e7a4654ea454915930fb8dd4882c6f294b95cf8", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:5efacf0ddad8fd852ba394b29e7a4654ea454915930fb8dd4882c6f294b95cf8", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.base_table_2,PROD)" }, { "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_another_project,PROD)" @@ -1448,6 +1768,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:b66112fa9691aa02354115b5cef8356390b524fa67c6b06e018c362ac8d0b31d", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "query", "entityUrn": "urn:li:query:dc49a3d580b4df6c8d24961c39a18b3569d8e58783fe9895324876da32d98d1e", @@ -1637,6 +1989,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:a4d62b3996203c5661d02d28c1908d209a56e9966cefc274600a76335bc75de0", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "dataset", "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db_2.table_from_other_db,PROD)", @@ -1667,6 +2051,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:bb1e3c0fd1f6a26c2645cf4ba088a22ff346a9e323c6be451459ecfa7329a991", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "dataset", "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.snapshot_from_table,PROD)", @@ -1866,6 +2282,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:bb3d7f6685e1f71868d0821451e52bfcf1a3bdfeb34c739c0305386256c38f9b", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "dataset", "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db_2.table_from_other_db,PROD)", @@ -2000,6 +2448,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:dc49a3d580b4df6c8d24961c39a18b3569d8e58783fe9895324876da32d98d1e", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "query", "entityUrn": "urn:li:query:bb3d7f6685e1f71868d0821451e52bfcf1a3bdfeb34c739c0305386256c38f9b", @@ -2238,39 +2718,45 @@ } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:630f9169072a11dfd8d08a44479f2466acdf2dc2b078b946a739db437b74ad1d", "changeType": "UPSERT", - "aspectName": "operation", + "aspectName": "queryUsageStatistics", "aspect": { "json": { - "timestampMillis": 1724064997271, + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, "partitionSpec": { "partition": "FULL_TABLE_SNAPSHOT", "type": "FULL_TABLE" }, - "actor": "urn:li:corpuser:dh-bigquery-smoke-test", - "operationType": "CREATE", - "customProperties": { - "query_urn": "urn:li:query:53d20616e4dd30dfc16ccc5771998f5ed93c9afa9b846104a19d072ba364fb5c" - }, - "lastUpdatedTimestamp": 1721549562792 + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] } }, "systemMetadata": { - "lastObserved": 1724064997273, - "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_view_and_table,PROD)", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD)", "changeType": "UPSERT", "aspectName": "operation", "aspect": { "json": { - "timestampMillis": 1724064997267, + "timestampMillis": 1724064997271, "partitionSpec": { "partition": "FULL_TABLE_SNAPSHOT", "type": "FULL_TABLE" @@ -2278,27 +2764,85 @@ "actor": "urn:li:corpuser:dh-bigquery-smoke-test", "operationType": "CREATE", "customProperties": { - "query_urn": "urn:li:query:a4d62b3996203c5661d02d28c1908d209a56e9966cefc274600a76335bc75de0" + "query_urn": "urn:li:query:53d20616e4dd30dfc16ccc5771998f5ed93c9afa9b846104a19d072ba364fb5c" }, - "lastUpdatedTimestamp": 1721549578210 + "lastUpdatedTimestamp": 1721549562792 } }, "systemMetadata": { - "lastObserved": 1724064997269, + "lastObserved": 1724064997273, "runId": "bigquery-queries-2024_08_19-16_26_33", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:e1769381f2d261efecb105f3ab6fc8a2fc6717a1509cc65ba125c03841b0923d", + "entityUrn": "urn:li:query:b9c1cbdddc1018284bdfb113865f5dc95b5c5a106c8e1dad1297bc9ef70debf1", "changeType": "UPSERT", - "aspectName": "querySubjects", + "aspectName": "queryUsageStatistics", "aspect": { "json": { - "subjects": [ + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ { - "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD)" + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_view_and_table,PROD)", + "changeType": "UPSERT", + "aspectName": "operation", + "aspect": { + "json": { + "timestampMillis": 1724064997267, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test", + "operationType": "CREATE", + "customProperties": { + "query_urn": "urn:li:query:a4d62b3996203c5661d02d28c1908d209a56e9966cefc274600a76335bc75de0" + }, + "lastUpdatedTimestamp": 1721549578210 + } + }, + "systemMetadata": { + "lastObserved": 1724064997269, + "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e1769381f2d261efecb105f3ab6fc8a2fc6717a1509cc65ba125c03841b0923d", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD)" }, { "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.materialized_view_from_table,PROD)" @@ -3114,6 +3658,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:2d4a0fdd933c8f9009a21f00b3b0213b025d97ff5e6a39cd031e9d5e5c31f832", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "dataset", "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.destination_table_of_select_query,PROD)", @@ -3273,6 +3849,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:4bd08adca1e16a1e10673f736ae2c91e0ee68fd56b187bd507f360e429dbcb8c", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "dataset", "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.usage_test,PROD)", @@ -3357,6 +3965,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:4f5fd82d4808115ef07900a543b7d6e3551899815d11a945870c607d2dbda56e", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "query", "entityUrn": "urn:li:query:b66112fa9691aa02354115b5cef8356390b524fa67c6b06e018c362ac8d0b31d", @@ -3380,6 +4020,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:420cad6350235517b34e6e376414d89be0734f87fba6789754be420051d4901c", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "dataset", "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.usage_test,PROD)", @@ -3765,6 +4437,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:cb345cc231c81ec7b871d6727437a87b5bc18a95ecf37e857f07096254c2d2c1", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "dataset", "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.materialized_view_from_table,PROD)", @@ -3919,6 +4623,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:005ef53d98fe9ce2d807a16f00695367e6923b11729f2fba0db3e694bd2fe9c9", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "query", "entityUrn": "urn:li:query:a4d62b3996203c5661d02d28c1908d209a56e9966cefc274600a76335bc75de0", @@ -4226,28 +4962,60 @@ } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.derived_table_from_sharded_table,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:6bbebdb71c5ef982b74fb6bbef58f7f33162566fd9b14385f2da971503317539", "changeType": "UPSERT", - "aspectName": "operation", + "aspectName": "queryUsageStatistics", "aspect": { "json": { - "timestampMillis": 1724065178300, + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, "partitionSpec": { "partition": "FULL_TABLE_SNAPSHOT", "type": "FULL_TABLE" }, - "actor": "urn:li:corpuser:dh-bigquery-smoke-test", - "operationType": "CREATE", - "customProperties": { - "query_urn": "urn:li:query:49b267d0cd050c6a45b4d26bcdc6d9ddceb51aa7ed29399c52ef967e8da2b58d" - }, - "lastUpdatedTimestamp": 1721549598252 + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] } }, "systemMetadata": { - "lastObserved": 1724065178302, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.derived_table_from_sharded_table,PROD)", + "changeType": "UPSERT", + "aspectName": "operation", + "aspect": { + "json": { + "timestampMillis": 1724065178300, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test", + "operationType": "CREATE", + "customProperties": { + "query_urn": "urn:li:query:49b267d0cd050c6a45b4d26bcdc6d9ddceb51aa7ed29399c52ef967e8da2b58d" + }, + "lastUpdatedTimestamp": 1721549598252 + } + }, + "systemMetadata": { + "lastObserved": 1724065178302, + "runId": "bigquery-queries-2024_08_19-16_29_19", "lastRunId": "no-run-id-provided" } }, @@ -4384,6 +5152,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e4e43fe8e17490b4b360a704a5604dd8d55763afd40f10c335e340132a9fe178", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "dataset", "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD)", @@ -4506,6 +5306,38 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:ccc4a40bb7abb852c9a97a2dc80c0928447bf28b91be0e41a80f691ca8e34e35", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "query", "entityUrn": "urn:li:query:e4e43fe8e17490b4b360a704a5604dd8d55763afd40f10c335e340132a9fe178", @@ -4522,6 +5354,70 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:2957e74d80b00aef4f3dc7b0b323d1fa863c78fd882d858186579c0737df00e2", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:a5b8ca0f0b97816db6ca440bdd7c6b11acc823fa70250396b902eb1d46835fbc", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "query", "entityUrn": "urn:li:query:e4e43fe8e17490b4b360a704a5604dd8d55763afd40f10c335e340132a9fe178", @@ -4623,6 +5519,34 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:1dcc7521d850077c51d832bc4da7c90aa7f4ea89ede1039363082d8db5c23132", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "SELECT\n (SUM(CASE WHEN amount BETWEEN 0 AND 10 THEN 1 ELSE 0 END) * 100.0) / COUNT(*) AS percentage_in_range\nFROM\n gcp-staging.customer_demo.purchase_event;", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724323167170, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724323167170, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "dataset", "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_view,PROD)", @@ -4639,6 +5563,45 @@ "lastRunId": "no-run-id-provided" } }, +{ + "entityType": "query", + "entityUrn": "urn:li:query:1dcc7521d850077c51d832bc4da7c90aa7f4ea89ede1039363082d8db5c23132", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:1dcc7521d850077c51d832bc4da7c90aa7f4ea89ede1039363082d8db5c23132", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.customer_demo.purchase_event,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.customer_demo.purchase_event,PROD),amount)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, { "entityType": "dataset", "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.lineage_from_base,PROD)", @@ -4682,68 +5645,68 @@ } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.partition_test,PROD)", - "changeType": "UPSERT", - "aspectName": "status", - "aspect": { - "json": { - "removed": false - } - }, - "systemMetadata": { - "lastObserved": 1724064997316, - "runId": "bigquery-queries-2024_08_19-16_26_33", - "lastRunId": "no-run-id-provided" - } -}, -{ - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_view_on_table,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:bf9835d210e6e397beb91a558bdf36ecb21f3bca9a4789f1f98d617f0aaaf441", "changeType": "UPSERT", - "aspectName": "status", + "aspectName": "queryUsageStatistics", "aspect": { "json": { - "removed": false + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] } }, "systemMetadata": { - "lastObserved": 1724064997320, - "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:ccc4a40bb7abb852c9a97a2dc80c0928447bf28b91be0e41a80f691ca8e34e35", + "entityUrn": "urn:li:query:9e7801810f6e4012bcbe249a5b9e20a5b3582065c09a3563124703315170dce4", "changeType": "UPSERT", "aspectName": "queryProperties", "aspect": { "json": { "statement": { - "value": "\n create or replace table `gcp-staging-2.smoke_test_db_4.sharded_table1_20230101` OPTIONS(description=\"Description of sharded table ending with _yyyyMMdd\") as (select * from `gcp-staging.smoke_test_db_2.table_from_other_db`) ;\n ", + "value": "select revenue, date_utc from gcp-staging.smoke_test_db.view_from_table", "language": "SQL" }, "source": "SYSTEM", "created": { - "time": 1721549588804, + "time": 1724322528915, "actor": "urn:li:corpuser:dh-bigquery-smoke-test" }, "lastModified": { - "time": 1721549588804, + "time": 1724322528915, "actor": "urn:li:corpuser:dh-bigquery-smoke-test" } } }, "systemMetadata": { - "lastObserved": 1724065178294, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.usage_test,PROD)", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.partition_test,PROD)", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -4752,30 +5715,5918 @@ } }, "systemMetadata": { - "lastObserved": 1724064997318, + "lastObserved": 1724064997316, "runId": "bigquery-queries-2024_08_19-16_26_33", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:ccc4a40bb7abb852c9a97a2dc80c0928447bf28b91be0e41a80f691ca8e34e35", + "entityUrn": "urn:li:query:9e7801810f6e4012bcbe249a5b9e20a5b3582065c09a3563124703315170dce4", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:741bb9b00959a800b366a27cd477f8f24292c3b3f0198213c5e06a79b0e00555", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue, date_utc from gcp-staging-2.smoke_test_db_4.sharded_table1_20230101", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322557063, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322557063, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:9e7801810f6e4012bcbe249a5b9e20a5b3582065c09a3563124703315170dce4", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_table,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_table,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_table,PROD),date_utc)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:741bb9b00959a800b366a27cd477f8f24292c3b3f0198213c5e06a79b0e00555", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:a1dd41eea989d820907358b594b3fb41e0d6812119f5ff657bb02e98dd4c6177", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "\n SELECT\n customer_id,\n date1\n FROM\n `gcp-staging-2.smoke_test_db_4.table_with_integer_range_partition`\n WHERE\n customer_id=1\n", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322609673, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322609673, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:741bb9b00959a800b366a27cd477f8f24292c3b3f0198213c5e06a79b0e00555", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD),date_utc)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:53d20616e4dd30dfc16ccc5771998f5ed93c9afa9b846104a19d072ba364fb5c", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:a1dd41eea989d820907358b594b3fb41e0d6812119f5ff657bb02e98dd4c6177", "changeType": "UPSERT", "aspectName": "dataPlatformInstance", "aspect": { "json": { - "platform": "urn:li:dataPlatform:bigquery" + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:a1dd41eea989d820907358b594b3fb41e0d6812119f5ff657bb02e98dd4c6177", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_integer_range_partition,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_integer_range_partition,PROD),date1)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_integer_range_partition,PROD),customer_id)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_view_on_table,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724064997320, + "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:ccc4a40bb7abb852c9a97a2dc80c0928447bf28b91be0e41a80f691ca8e34e35", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "\n create or replace table `gcp-staging-2.smoke_test_db_4.sharded_table1_20230101` OPTIONS(description=\"Description of sharded table ending with _yyyyMMdd\") as (select * from `gcp-staging.smoke_test_db_2.table_from_other_db`) ;\n ", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1721549588804, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1721549588804, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724065178294, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.usage_test,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724064997318, + "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f23fd4d501b4de8c50e206db9d8c62f23f92016bab643a168231da54c4a64c88", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f53151fa3d689ec865c53fa535479e3fc3cc5794be5daaa9a5a4f7f40a7c660f", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:ccc4a40bb7abb852c9a97a2dc80c0928447bf28b91be0e41a80f691ca8e34e35", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724065178295, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:ebfe552aa0ddb538f3a6c4d444aff757e6df574f16a6dffc3ac146ce587fc491", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.derived_table_from_timetravelled_table,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178326, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:577b11663e044d6b6cab9e2732b49f9ddbd4ad02fa4244c1d338c5d4167b3a9d", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:fdeaa6e036cca324d7f80811a5f3563986866007bfc7ab1b8bb69515cc38f5f6", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue, date_utc from gcp-staging-2.smoke_test_db_3.base_table_2", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322551240, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322551240, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:ccc4a40bb7abb852c9a97a2dc80c0928447bf28b91be0e41a80f691ca8e34e35", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db_2.table_from_other_db,PROD)" + }, + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724065178294, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:fdeaa6e036cca324d7f80811a5f3563986866007bfc7ab1b8bb69515cc38f5f6", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:9b7b2966ae76644cacd808f503c9c5a9d2328e6526fd0b9f4d37fd70fbcf6553", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "SELECT COUNT(*) FROM gcp-staging.customer_demo.purchase_event WHERE user_id IS NULL", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724323170390, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724323170390, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:70d19c139e7fa4f808045ce1b60c3d3a0d9284ae4acc00b5446c27fe1111a6a6", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 21, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 21 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e1b3aa8663b4502df2c6f2db4aaeea00df94105fcbe0519e224549c9d982987e", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:fdeaa6e036cca324d7f80811a5f3563986866007bfc7ab1b8bb69515cc38f5f6", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.base_table_2,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.base_table_2,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.base_table_2,PROD),date_utc)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:9b7b2966ae76644cacd808f503c9c5a9d2328e6526fd0b9f4d37fd70fbcf6553", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:9b7b2966ae76644cacd808f503c9c5a9d2328e6526fd0b9f4d37fd70fbcf6553", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.customer_demo.purchase_event,PROD)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:2957e74d80b00aef4f3dc7b0b323d1fa863c78fd882d858186579c0737df00e2", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724064498948, + "runId": "bigquery-queries-2024_08_19-16_18_14", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.destination_table_of_select_query,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:3ec450841af8056dd02a1f9f059b234119985c2780a30dc38dda726a8b4426dc", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue, date_utc from gcp-staging.smoke_test_db.lineage_from_tmp_table", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322522802, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322522802, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f53151fa3d689ec865c53fa535479e3fc3cc5794be5daaa9a5a4f7f40a7c660f", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "\n create or replace table `gcp-staging-2.smoke_test_db_3.base_table_2` (date_utc timestamp, revenue INTEGER);\n ", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1721549582803, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1721549582803, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724065178290, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:8714510dd7dc19deccb3188a5e9896076244ff203155e5fa4b61b70121789153", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:1796e9c3a125d6474ce2f1fbe1f498d028015b5d7bfd90549dcfcd026826a68f", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:3ec450841af8056dd02a1f9f059b234119985c2780a30dc38dda726a8b4426dc", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:3ec450841af8056dd02a1f9f059b234119985c2780a30dc38dda726a8b4426dc", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.lineage_from_tmp_table,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.lineage_from_tmp_table,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.lineage_from_tmp_table,PROD),date_utc)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:a5b8ca0f0b97816db6ca440bdd7c6b11acc823fa70250396b902eb1d46835fbc", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724064498951, + "runId": "bigquery-queries-2024_08_19-16_18_14", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f53151fa3d689ec865c53fa535479e3fc3cc5794be5daaa9a5a4f7f40a7c660f", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724065178291, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:c0552a77514094a5c86fc63041e11a30bcf8985511a85d086695db70939abcc0", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue from gcp-staging.smoke_test_db.table_from_another_project", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322555601, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322555601, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f53151fa3d689ec865c53fa535479e3fc3cc5794be5daaa9a5a4f7f40a7c660f", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.base_table_2,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.base_table_2,PROD),date_utc)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.base_table_2,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724065178290, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:c0552a77514094a5c86fc63041e11a30bcf8985511a85d086695db70939abcc0", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:039ed54536f1c5bb1ee61f6a6e1f67878c952190620ea30e48768cac208fbe57", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue, date_utc from gcp-staging.smoke_test_db.base_table", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322514004, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322514004, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:3989b79902a8974efeffb0c6e2fb5f5e935abd1ce2beb278a876286038a352d0", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue, date_utc from gcp-staging.smoke_test_db.lineage_from_base", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322525871, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322525871, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:039ed54536f1c5bb1ee61f6a6e1f67878c952190620ea30e48768cac208fbe57", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:039ed54536f1c5bb1ee61f6a6e1f67878c952190620ea30e48768cac208fbe57", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD),date_utc)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:c0552a77514094a5c86fc63041e11a30bcf8985511a85d086695db70939abcc0", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_another_project,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_another_project,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:3989b79902a8974efeffb0c6e2fb5f5e935abd1ce2beb278a876286038a352d0", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:3989b79902a8974efeffb0c6e2fb5f5e935abd1ce2beb278a876286038a352d0", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.lineage_from_base,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.lineage_from_base,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.lineage_from_base,PROD),date_utc)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:4f5fd82d4808115ef07900a543b7d6e3551899815d11a945870c607d2dbda56e", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724064498948, + "runId": "bigquery-queries-2024_08_19-16_18_14", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:53d20616e4dd30dfc16ccc5771998f5ed93c9afa9b846104a19d072ba364fb5c", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724064498949, + "runId": "bigquery-queries-2024_08_19-16_18_14", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:c0182ee336ef4bb9c8e957bc621616573c9aea2a2c0ed08ddd04b1aab2e0ab39", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724064997314, + "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:c1c334538a103cfd23352131c5de23677521e78bf74a16021d4877695074c63a", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:bb1e3c0fd1f6a26c2645cf4ba088a22ff346a9e323c6be451459ecfa7329a991", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724064498952, + "runId": "bigquery-queries-2024_08_19-16_18_14", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:bb3d7f6685e1f71868d0821451e52bfcf1a3bdfeb34c739c0305386256c38f9b", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724064498952, + "runId": "bigquery-queries-2024_08_19-16_18_14", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:34e3010e0e6a4b83d275086601e9ece3083e1ecc5dae3945bbd75631fa5d4126", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue, date_utc from gcp-staging.smoke_test_db.materialized_view_from_table", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322541401, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322541401, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_ingestion_time_partition,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178327, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:34e3010e0e6a4b83d275086601e9ece3083e1ecc5dae3945bbd75631fa5d4126", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:59c53a03b1fbf71b46518f56b26e7cc3cf03a726567e15cc9d37e6dd2f5c1f60", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:34e3010e0e6a4b83d275086601e9ece3083e1ecc5dae3945bbd75631fa5d4126", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.materialized_view_from_table,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.materialized_view_from_table,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.materialized_view_from_table,PROD),date_utc)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:b66112fa9691aa02354115b5cef8356390b524fa67c6b06e018c362ac8d0b31d", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724064498952, + "runId": "bigquery-queries-2024_08_19-16_18_14", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_view_and_table,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724064997317, + "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:c45ca09d68c89c18308b4eb97b2497a1a7c40a21de17b6ea06beab10704a3e3e", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:1796e9c3a125d6474ce2f1fbe1f498d028015b5d7bfd90549dcfcd026826a68f", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue, date_utc from gcp-staging.smoke_test_db.view_from_view_on_table", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322532005, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322532005, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:055def6c8c2745212afa56be1f58fbdc936cd7f37a420a7df6715416fddae4dc", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_multiple_tables,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724064997318, + "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:1796e9c3a125d6474ce2f1fbe1f498d028015b5d7bfd90549dcfcd026826a68f", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:1796e9c3a125d6474ce2f1fbe1f498d028015b5d7bfd90549dcfcd026826a68f", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_view_on_table,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_view_on_table,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_view_on_table,PROD),date_utc)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db_2.table_from_other_db,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724064997320, + "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_snapshot_on_table,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724064997319, + "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:c0182ee336ef4bb9c8e957bc621616573c9aea2a2c0ed08ddd04b1aab2e0ab39", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue from gcp-staging.smoke_test_db.lineage_from_tmp_table", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322524291, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322524291, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:84a5f2c31752cc1a4e180c86da34c84f1a04df3b69aebe0d69222d0d8e07f8e0", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue from gcp-staging-2.smoke_test_db_4.sharded_table1_20230201", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322561765, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322561765, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:c0182ee336ef4bb9c8e957bc621616573c9aea2a2c0ed08ddd04b1aab2e0ab39", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:604fa496a50ed8bd340161bebdc475d68daffeaaed31ec649370a2ce392eed90", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue from gcp-staging.smoke_test_db.lineage_from_base", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322527479, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322527479, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:95daf40bccda9fbc9dc15b1109fa105a3c19d83de58625b7265e81cbe8dae940", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "\n select \n transaction_id \n from \n `gcp-staging-2.smoke_test_db_4.table_with_ingestion_time_partition` \n where \n _PARTITIONDATE = CURRENT_DATE()\n", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322608186, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322608186, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:604fa496a50ed8bd340161bebdc475d68daffeaaed31ec649370a2ce392eed90", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:604fa496a50ed8bd340161bebdc475d68daffeaaed31ec649370a2ce392eed90", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.lineage_from_base,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.lineage_from_base,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:82edd8e24a1c289c4c7487b5a3c1b61e4ed6f1c89d5cd2fab5424b085ad0b7d6", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:c0182ee336ef4bb9c8e957bc621616573c9aea2a2c0ed08ddd04b1aab2e0ab39", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.lineage_from_tmp_table,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.lineage_from_tmp_table,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:95daf40bccda9fbc9dc15b1109fa105a3c19d83de58625b7265e81cbe8dae940", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:577b11663e044d6b6cab9e2732b49f9ddbd4ad02fa4244c1d338c5d4167b3a9d", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue from gcp-staging.smoke_test_db_2.table_from_other_db", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322549851, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322549851, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:95daf40bccda9fbc9dc15b1109fa105a3c19d83de58625b7265e81cbe8dae940", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_ingestion_time_partition,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_ingestion_time_partition,PROD),transaction_id)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:577b11663e044d6b6cab9e2732b49f9ddbd4ad02fa4244c1d338c5d4167b3a9d", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6264af081391592ea07c46c6aea5ec4359b4ac5ec695976469b461b9de5be3f2", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 36, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 36 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:c0552a77514094a5c86fc63041e11a30bcf8985511a85d086695db70939abcc0", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:577b11663e044d6b6cab9e2732b49f9ddbd4ad02fa4244c1d338c5d4167b3a9d", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db_2.table_from_other_db,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db_2.table_from_other_db,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:32b43422c0184159f4f812fb8e698ed2423a421a7086864aeb11efc3c339246e", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_table,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724064997319, + "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:84a5f2c31752cc1a4e180c86da34c84f1a04df3b69aebe0d69222d0d8e07f8e0", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:c45ca09d68c89c18308b4eb97b2497a1a7c40a21de17b6ea06beab10704a3e3e", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue from `gcp-staging-2.smoke_test_db_4.sharded_table1_*`", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322565044, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322565044, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:84a5f2c31752cc1a4e180c86da34c84f1a04df3b69aebe0d69222d0d8e07f8e0", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:c45ca09d68c89c18308b4eb97b2497a1a7c40a21de17b6ea06beab10704a3e3e", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f0faa4e0dbe3a28dc69369034ffde5f0cbba1f0a068a1db914bf143dc212aeb6", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:c45ca09d68c89c18308b4eb97b2497a1a7c40a21de17b6ea06beab10704a3e3e", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:composite_0db44e02f671b69df68565346e9d2b68c7166fccf75bd494f34560bfa16c381b", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724064997332, + "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6bbebdb71c5ef982b74fb6bbef58f7f33162566fd9b14385f2da971503317539", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_integer_range_partition,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_integer_range_partition,PROD),customer_id)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_integer_range_partition,PROD),date1)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724065178301, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:56740f3a3d46afdf0177aadf1dbf4937a4b83c0116aef2773a5de9b7e87895f2", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e0e0eb18099d8d8a8ef58c5c7cdaf0948774f0fe02ccd1c1c940b502b69c8483", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select key from gcp-staging.smoke_test_db.usage_test", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322595586, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322595586, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e0e0eb18099d8d8a8ef58c5c7cdaf0948774f0fe02ccd1c1c940b502b69c8483", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 3, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 3 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:95daf40bccda9fbc9dc15b1109fa105a3c19d83de58625b7265e81cbe8dae940", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6bbebdb71c5ef982b74fb6bbef58f7f33162566fd9b14385f2da971503317539", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "\n CREATE or REPLACE TABLE `gcp-staging-2.smoke_test_db_4.table_with_integer_range_partition` (customer_id INT64, date1 DATE)\n PARTITION BY\n RANGE_BUCKET(customer_id, GENERATE_ARRAY(0, 100, 10))\n OPTIONS (\n description = \"Description of Integer Range partitioned table\",\n require_partition_filter = TRUE);\n ", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1721549596824, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1721549596824, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724065178301, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:34e3010e0e6a4b83d275086601e9ece3083e1ecc5dae3945bbd75631fa5d4126", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e0e0eb18099d8d8a8ef58c5c7cdaf0948774f0fe02ccd1c1c940b502b69c8483", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:bf9835d210e6e397beb91a558bdf36ecb21f3bca9a4789f1f98d617f0aaaf441", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue from gcp-staging.smoke_test_db.materialized_view_from_table", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322543069, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322543069, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e0e0eb18099d8d8a8ef58c5c7cdaf0948774f0fe02ccd1c1c940b502b69c8483", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.usage_test,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.usage_test,PROD),key)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6422d5a3e23d0bfce3783edc019406cc6cc574044faa5c48edb97cf22294ba33", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:bf9835d210e6e397beb91a558bdf36ecb21f3bca9a4789f1f98d617f0aaaf441", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:039ed54536f1c5bb1ee61f6a6e1f67878c952190620ea30e48768cac208fbe57", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:bf9835d210e6e397beb91a558bdf36ecb21f3bca9a4789f1f98d617f0aaaf441", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.materialized_view_from_table,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.materialized_view_from_table,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6bbebdb71c5ef982b74fb6bbef58f7f33162566fd9b14385f2da971503317539", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178339, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.derived_table_from_sharded_table,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178325, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:859633a51baed3d25e0fda695c858b9981f7f5a2f7a7073b251847704e184083", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue, date_utc from gcp-staging.smoke_test_db.table_from_another_project", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322554152, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322554152, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.derived_table,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178325, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:859633a51baed3d25e0fda695c858b9981f7f5a2f7a7073b251847704e184083", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:859633a51baed3d25e0fda695c858b9981f7f5a2f7a7073b251847704e184083", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_another_project,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_another_project,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_another_project,PROD),date_utc)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6bbebdb71c5ef982b74fb6bbef58f7f33162566fd9b14385f2da971503317539", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724065178301, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_nested_fields,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178328, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:859633a51baed3d25e0fda695c858b9981f7f5a2f7a7073b251847704e184083", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:ef372dc8ac2bd484b844e59ea85f81361950f4897a7382df59fb0d4584468fc6", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 4, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 4 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:dd46e45d678f4e7a2755637ac76b97a1d1c723602f767b2fa0f8653920bb8d99", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue from gcp-staging.smoke_test_db.table_from_view_and_table", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322539969, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322539969, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:9f2cdfe3c23dd5eb43051d0b683a9e76cd40453f3cba44c750f98de294134e03", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue, date_utc from gcp-staging.smoke_test_db.base_table FOR SYSTEM_TIME AS OF TIMESTAMP_SUB(CURRENT_TIMESTAMP(), INTERVAL 1 HOUR)", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322611320, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322611320, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:dd46e45d678f4e7a2755637ac76b97a1d1c723602f767b2fa0f8653920bb8d99", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:dd46e45d678f4e7a2755637ac76b97a1d1c723602f767b2fa0f8653920bb8d99", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_view_and_table,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_view_and_table,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:44c19e1fccfa56779f6958f62d3476819b48af701bbee43ccecf5c9e04d63fc4", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:9f2cdfe3c23dd5eb43051d0b683a9e76cd40453f3cba44c750f98de294134e03", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:9f2cdfe3c23dd5eb43051d0b683a9e76cd40453f3cba44c750f98de294134e03", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD),date_utc)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f53151fa3d689ec865c53fa535479e3fc3cc5794be5daaa9a5a4f7f40a7c660f", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178346, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_integer_range_partition,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178328, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:3b9dab2ff83d72565bd19daefcee18b938db280a5c030ccf36fb511f19f929c6", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue from gcp-staging-2.smoke_test_db_3.base_table_2", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322552655, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322552655, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:101f80da8c082437fb8997d9fa1df63c1c65258e51d89516922e6b61b39c32dc", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue from gcp-staging.smoke_test_db.view_from_table", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322530411, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322530411, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:3b9dab2ff83d72565bd19daefcee18b938db280a5c030ccf36fb511f19f929c6", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:276cc9d6fa5b1277b2de3d278060c5628f13907b0c1a748edd7595a7e38b1181", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue from gcp-staging.smoke_test_db.base_table FOR SYSTEM_TIME AS OF TIMESTAMP_SUB(CURRENT_TIMESTAMP(), INTERVAL 1 HOUR)", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322612787, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322612787, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:3b9dab2ff83d72565bd19daefcee18b938db280a5c030ccf36fb511f19f929c6", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.base_table_2,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.base_table_2,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:276cc9d6fa5b1277b2de3d278060c5628f13907b0c1a748edd7595a7e38b1181", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:276cc9d6fa5b1277b2de3d278060c5628f13907b0c1a748edd7595a7e38b1181", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:5efacf0ddad8fd852ba394b29e7a4654ea454915930fb8dd4882c6f294b95cf8", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178338, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:101f80da8c082437fb8997d9fa1df63c1c65258e51d89516922e6b61b39c32dc", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:101f80da8c082437fb8997d9fa1df63c1c65258e51d89516922e6b61b39c32dc", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_table,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_table,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.derived_table_from_wildcard_table,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178326, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:420cad6350235517b34e6e376414d89be0734f87fba6789754be420051d4901c", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_ingestion_time_partition,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_ingestion_time_partition,PROD),transaction_id)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724065178310, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6422d5a3e23d0bfce3783edc019406cc6cc574044faa5c48edb97cf22294ba33", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "\n select name, post_abbr from `gcp-staging-2.smoke_test_db_4.external_table_us_states`\n", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322605248, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322605248, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:276cc9d6fa5b1277b2de3d278060c5628f13907b0c1a748edd7595a7e38b1181", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:d326639002bca6c0fe8515dc1599fd1a81f35bbde61806f2fa19487201f7a79f", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:420cad6350235517b34e6e376414d89be0734f87fba6789754be420051d4901c", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "\n CREATE or REPLACE TABLE\n `gcp-staging-2.smoke_test_db_4.table_with_ingestion_time_partition` (transaction_id INT64)\n PARTITION BY\n _PARTITIONDATE\n OPTIONS (\n description = \"Description of Ingestion time partitioned table\",\n partition_expiration_days = 3,\n require_partition_filter = TRUE);\n ", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1721549596155, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1721549596155, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724065178309, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6422d5a3e23d0bfce3783edc019406cc6cc574044faa5c48edb97cf22294ba33", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:a1dd41eea989d820907358b594b3fb41e0d6812119f5ff657bb02e98dd4c6177", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6422d5a3e23d0bfce3783edc019406cc6cc574044faa5c48edb97cf22294ba33", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.external_table_us_states,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.external_table_us_states,PROD),name)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.external_table_us_states,PROD),post_abbr)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:420cad6350235517b34e6e376414d89be0734f87fba6789754be420051d4901c", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178336, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:420cad6350235517b34e6e376414d89be0734f87fba6789754be420051d4901c", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724065178310, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:84a5f2c31752cc1a4e180c86da34c84f1a04df3b69aebe0d69222d0d8e07f8e0", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:aabff37598818c2571a6f1d31137c66ba2a19cae73cc65514a92e703a0b70511", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue from gcp-staging.smoke_test_db.view_from_multiple_tables", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322546639, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322546639, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f5c935d2377600d41fa76c69b80586aaa0c373b527b9ae46ca62982c53193ad5", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 5, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 5 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.customer_demo.purchase_event,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178329, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:aabff37598818c2571a6f1d31137c66ba2a19cae73cc65514a92e703a0b70511", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:1f994d5cfc676f126b1d43b02e1c2f6640e7375c9d8d50b3a5bad6ba057745ab", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 3, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 3 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:101f80da8c082437fb8997d9fa1df63c1c65258e51d89516922e6b61b39c32dc", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:991a14a8ed8d532c930c8dfd2ace42a7a5fafb76a7a505e14f373e62e8807e0b", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:1f994d5cfc676f126b1d43b02e1c2f6640e7375c9d8d50b3a5bad6ba057745ab", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select value from gcp-staging.smoke_test_db.usage_test", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322594074, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322594074, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:ef372dc8ac2bd484b844e59ea85f81361950f4897a7382df59fb0d4584468fc6", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select * from gcp-staging.smoke_test_db.usage_test", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322601431, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322601431, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:9b7b2966ae76644cacd808f503c9c5a9d2328e6526fd0b9f4d37fd70fbcf6553", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 14, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 14 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:1f994d5cfc676f126b1d43b02e1c2f6640e7375c9d8d50b3a5bad6ba057745ab", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:1f994d5cfc676f126b1d43b02e1c2f6640e7375c9d8d50b3a5bad6ba057745ab", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.usage_test,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.usage_test,PROD),value)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:aabff37598818c2571a6f1d31137c66ba2a19cae73cc65514a92e703a0b70511", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_multiple_tables,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_multiple_tables,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:ef372dc8ac2bd484b844e59ea85f81361950f4897a7382df59fb0d4584468fc6", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:ef372dc8ac2bd484b844e59ea85f81361950f4897a7382df59fb0d4584468fc6", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.usage_test,PROD)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:2fa44cc9d306c7523477fad59ff43e2e580081ee770da69b9b9f66e119b4dcab", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178336, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:ccc4a40bb7abb852c9a97a2dc80c0928447bf28b91be0e41a80f691ca8e34e35", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178344, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:b30be114c7808b5af8eb79c3ef07a96927372b12f7b03f23d786844ba0301882", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "\n SELECT COUNT(*)\n FROM gcp-staging.customer_demo.purchase_event\n WHERE quantity < 0\n ", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724323108678, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724323108678, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6684f16158660588d874f7ac46dbd7e56ad42acfb95b8a3d1f01292de8dcb930", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178339, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:b30be114c7808b5af8eb79c3ef07a96927372b12f7b03f23d786844ba0301882", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f0faa4e0dbe3a28dc69369034ffde5f0cbba1f0a068a1db914bf143dc212aeb6", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue, date_utc from gcp-staging.smoke_test_db.view_from_multiple_tables", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322544870, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322544870, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:b30be114c7808b5af8eb79c3ef07a96927372b12f7b03f23d786844ba0301882", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.customer_demo.purchase_event,PROD)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f0faa4e0dbe3a28dc69369034ffde5f0cbba1f0a068a1db914bf143dc212aeb6", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:b5f379bdbfa48c81469b0a5893bb649ba02ff71fcd4ff151675c8728472c9219", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue, date_utc from `gcp-staging-2.smoke_test_db_4.sharded_table1_*`", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322563212, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322563212, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f0faa4e0dbe3a28dc69369034ffde5f0cbba1f0a068a1db914bf143dc212aeb6", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_multiple_tables,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_multiple_tables,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_multiple_tables,PROD),date_utc)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:b5f379bdbfa48c81469b0a5893bb649ba02ff71fcd4ff151675c8728472c9219", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:b5f379bdbfa48c81469b0a5893bb649ba02ff71fcd4ff151675c8728472c9219", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD),date_utc)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.external_table_us_states,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178327, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:2d4a0fdd933c8f9009a21f00b3b0213b025d97ff5e6a39cd031e9d5e5c31f832", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178335, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:4c01c67bbeca250453b9063e03964cc1bd358921ca0b650140515e79d1970db8", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 5, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 5 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:32b43422c0184159f4f812fb8e698ed2423a421a7086864aeb11efc3c339246e", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue, date_utc from gcp-staging.smoke_test_db.partition_test", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322518956, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322518956, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:b30be114c7808b5af8eb79c3ef07a96927372b12f7b03f23d786844ba0301882", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 5, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 5 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:88c4674d369ef49e881a5ea67ed3485e48f09b9a4924d5282c3ae25004737f95", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178340, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:b828588160530bade966b0dbe1c1d09fb3262f6b9137c0956a6f3ed4ef467a91", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 3, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 3 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:32b43422c0184159f4f812fb8e698ed2423a421a7086864aeb11efc3c339246e", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:32b43422c0184159f4f812fb8e698ed2423a421a7086864aeb11efc3c339246e", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.partition_test,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.partition_test,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.partition_test,PROD),date_utc)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178327, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.derived_table_from_external_table,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178325, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:82edd8e24a1c289c4c7487b5a3c1b61e4ed6f1c89d5cd2fab5424b085ad0b7d6", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "\n SELECT\n first_name,\n last_name,\n dob,\n addresses[offset(0)].address,\n addresses[offset(0)].city\n FROM \n gcp-staging-2.smoke_test_db_4.table_with_nested_fields\n", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322606806, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322606806, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.base_table_2,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178324, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:82edd8e24a1c289c4c7487b5a3c1b61e4ed6f1c89d5cd2fab5424b085ad0b7d6", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:82edd8e24a1c289c4c7487b5a3c1b61e4ed6f1c89d5cd2fab5424b085ad0b7d6", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_nested_fields,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_nested_fields,PROD),last_name)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_nested_fields,PROD),first_name)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_nested_fields,PROD),addresses)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_nested_fields,PROD),dob)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:741bb9b00959a800b366a27cd477f8f24292c3b3f0198213c5e06a79b0e00555", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:fdeaa6e036cca324d7f80811a5f3563986866007bfc7ab1b8bb69515cc38f5f6", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:7a4b43ffafd0fb61a647ed56a9383a42fb902f5632a9608c72229ad9da5d4d1c", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:49b267d0cd050c6a45b4d26bcdc6d9ddceb51aa7ed29399c52ef967e8da2b58d", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178337, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e4e43fe8e17490b4b360a704a5604dd8d55763afd40f10c335e340132a9fe178", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178345, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "dataset", + "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_another_project,PROD)", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178331, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:a049f27174fa88a7a7b1b7d5f60d2c353f3e9dd3d4994a8e35c91adb986eac4d", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178341, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6e250c6966754a5e6532fbb444172dacf5813b0b7afceefbf7772a29878f48f8", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724065178339, + "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:b5f379bdbfa48c81469b0a5893bb649ba02ff71fcd4ff151675c8728472c9219", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:1dcc7521d850077c51d832bc4da7c90aa7f4ea89ede1039363082d8db5c23132", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 3, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 3 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:3989b79902a8974efeffb0c6e2fb5f5e935abd1ce2beb278a876286038a352d0", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:4c01c67bbeca250453b9063e03964cc1bd358921ca0b650140515e79d1970db8", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.partition_test,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.partition_test,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:4c01c67bbeca250453b9063e03964cc1bd358921ca0b650140515e79d1970db8", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:4c01c67bbeca250453b9063e03964cc1bd358921ca0b650140515e79d1970db8", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "\n select revenue from gcp-staging.smoke_test_db.partition_test t\n where cast(t.date_utc as DATE) < (select max(date_utc) from gcp-staging.smoke_test_db.partition_test)\n", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322579451, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322579451, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:b828588160530bade966b0dbe1c1d09fb3262f6b9137c0956a6f3ed4ef467a91", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "\n select revenue from gcp-staging.smoke_test_db.partition_test t\n where cast(t.date_utc as DATE) = (select max(date_utc) from gcp-staging.smoke_test_db.partition_test)\n", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322585961, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322585961, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:991a14a8ed8d532c930c8dfd2ace42a7a5fafb76a7a505e14f373e62e8807e0b", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue from gcp-staging.smoke_test_db.partition_test", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322521153, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322521153, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:b828588160530bade966b0dbe1c1d09fb3262f6b9137c0956a6f3ed4ef467a91", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:b828588160530bade966b0dbe1c1d09fb3262f6b9137c0956a6f3ed4ef467a91", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.partition_test,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.partition_test,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:604fa496a50ed8bd340161bebdc475d68daffeaaed31ec649370a2ce392eed90", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:4c01c67bbeca250453b9063e03964cc1bd358921ca0b650140515e79d1970db8", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:991a14a8ed8d532c930c8dfd2ace42a7a5fafb76a7a505e14f373e62e8807e0b", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:991a14a8ed8d532c930c8dfd2ace42a7a5fafb76a7a505e14f373e62e8807e0b", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.partition_test,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.partition_test,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f23fd4d501b4de8c50e206db9d8c62f23f92016bab643a168231da54c4a64c88", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db_2.table_from_other_db,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db_2.table_from_other_db,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db_2.table_from_other_db,PROD),date_utc)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f23fd4d501b4de8c50e206db9d8c62f23f92016bab643a168231da54c4a64c88", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f23fd4d501b4de8c50e206db9d8c62f23f92016bab643a168231da54c4a64c88", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue, date_utc from gcp-staging.smoke_test_db_2.table_from_other_db", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322548392, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322548392, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f23fd4d501b4de8c50e206db9d8c62f23f92016bab643a168231da54c4a64c88", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e8ab557dc3577da354c52bb0acf3363d444578aeceeeed82cd6bcaa50453fd40", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:3ec450841af8056dd02a1f9f059b234119985c2780a30dc38dda726a8b4426dc", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:9f2cdfe3c23dd5eb43051d0b683a9e76cd40453f3cba44c750f98de294134e03", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:56740f3a3d46afdf0177aadf1dbf4937a4b83c0116aef2773a5de9b7e87895f2", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue from gcp-staging.smoke_test_db.base_table", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322517386, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322517386, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e8ab557dc3577da354c52bb0acf3363d444578aeceeeed82cd6bcaa50453fd40", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:56740f3a3d46afdf0177aadf1dbf4937a4b83c0116aef2773a5de9b7e87895f2", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:56740f3a3d46afdf0177aadf1dbf4937a4b83c0116aef2773a5de9b7e87895f2", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD),revenue)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:3b9dab2ff83d72565bd19daefcee18b938db280a5c030ccf36fb511f19f929c6", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e8ab557dc3577da354c52bb0acf3363d444578aeceeeed82cd6bcaa50453fd40", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "create or replace table _smoke_test_db_tmp_tables.tmp_table as (select * from smoke_test_db.base_table)", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322455205, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322455205, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e8ab557dc3577da354c52bb0acf3363d444578aeceeeed82cd6bcaa50453fd40", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f5c935d2377600d41fa76c69b80586aaa0c373b527b9ae46ca62982c53193ad5", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "\n select extract(month from date_utc) month, count(*) count, sum(revenue) gross from gcp-staging.smoke_test_db.partition_test\n group by month\n order by gross\n", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322581032, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322581032, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:8714510dd7dc19deccb3188a5e9896076244ff203155e5fa4b61b70121789153", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.usage_test,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.usage_test,PROD),date_utc)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.usage_test,PROD),value)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f5c935d2377600d41fa76c69b80586aaa0c373b527b9ae46ca62982c53193ad5", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:1f994d5cfc676f126b1d43b02e1c2f6640e7375c9d8d50b3a5bad6ba057745ab", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:aabff37598818c2571a6f1d31137c66ba2a19cae73cc65514a92e703a0b70511", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:70d19c139e7fa4f808045ce1b60c3d3a0d9284ae4acc00b5446c27fe1111a6a6", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "SELECT AVG(amount) FROM gcp-staging.customer_demo.purchase_event", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724323320672, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724323320672, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:f5c935d2377600d41fa76c69b80586aaa0c373b527b9ae46ca62982c53193ad5", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.partition_test,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.partition_test,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.partition_test,PROD),date_utc)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:70d19c139e7fa4f808045ce1b60c3d3a0d9284ae4acc00b5446c27fe1111a6a6", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:70d19c139e7fa4f808045ce1b60c3d3a0d9284ae4acc00b5446c27fe1111a6a6", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.customer_demo.purchase_event,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.customer_demo.purchase_event,PROD),amount)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:8714510dd7dc19deccb3188a5e9896076244ff203155e5fa4b61b70121789153", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:8714510dd7dc19deccb3188a5e9896076244ff203155e5fa4b61b70121789153", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "\n select extract(month from date_utc) month, count(*) count, sum(value) total from gcp-staging.smoke_test_db.usage_test\n group by month\n order by total\n ", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322602823, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322602823, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:8714510dd7dc19deccb3188a5e9896076244ff203155e5fa4b61b70121789153", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:34e3010e0e6a4b83d275086601e9ece3083e1ecc5dae3945bbd75631fa5d4126", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:84a5f2c31752cc1a4e180c86da34c84f1a04df3b69aebe0d69222d0d8e07f8e0", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:9f2cdfe3c23dd5eb43051d0b683a9e76cd40453f3cba44c750f98de294134e03", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:b30be114c7808b5af8eb79c3ef07a96927372b12f7b03f23d786844ba0301882", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6264af081391592ea07c46c6aea5ec4359b4ac5ec695976469b461b9de5be3f2", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.customer_demo.purchase_event,PROD)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:dd46e45d678f4e7a2755637ac76b97a1d1c723602f767b2fa0f8653920bb8d99", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test-2", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6264af081391592ea07c46c6aea5ec4359b4ac5ec695976469b461b9de5be3f2", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6264af081391592ea07c46c6aea5ec4359b4ac5ec695976469b461b9de5be3f2", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "\n SELECT COUNT(*)\n FROM gcp-staging.customer_demo.purchase_event\n WHERE amount < 0\n ", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724323321938, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724323321938, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:6264af081391592ea07c46c6aea5ec4359b4ac5ec695976469b461b9de5be3f2", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:101f80da8c082437fb8997d9fa1df63c1c65258e51d89516922e6b61b39c32dc", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e1b3aa8663b4502df2c6f2db4aaeea00df94105fcbe0519e224549c9d982987e", + "changeType": "UPSERT", + "aspectName": "querySubjects", + "aspect": { + "json": { + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_view_and_table,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_view_and_table,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_view_and_table,PROD),date_utc)" + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e1b3aa8663b4502df2c6f2db4aaeea00df94105fcbe0519e224549c9d982987e", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e1b3aa8663b4502df2c6f2db4aaeea00df94105fcbe0519e224549c9d982987e", + "changeType": "UPSERT", + "aspectName": "queryProperties", + "aspect": { + "json": { + "statement": { + "value": "select revenue, date_utc from gcp-staging.smoke_test_db.table_from_view_and_table", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322538350, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322538350, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:276cc9d6fa5b1277b2de3d278060c5628f13907b0c1a748edd7595a7e38b1181", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e8ab557dc3577da354c52bb0acf3363d444578aeceeeed82cd6bcaa50453fd40", + "changeType": "UPSERT", + "aspectName": "queryUsageStatistics", + "aspect": { + "json": { + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 + }, + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" + }, + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:e1b3aa8663b4502df2c6f2db4aaeea00df94105fcbe0519e224549c9d982987e", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:577b11663e044d6b6cab9e2732b49f9ddbd4ad02fa4244c1d338c5d4167b3a9d", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false } }, "systemMetadata": { - "lastObserved": 1724065178295, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.derived_table_from_timetravelled_table,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:859633a51baed3d25e0fda695c858b9981f7f5a2f7a7073b251847704e184083", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -4784,53 +11635,37 @@ } }, "systemMetadata": { - "lastObserved": 1724065178326, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:ccc4a40bb7abb852c9a97a2dc80c0928447bf28b91be0e41a80f691ca8e34e35", + "entityUrn": "urn:li:query:c1c334538a103cfd23352131c5de23677521e78bf74a16021d4877695074c63a", "changeType": "UPSERT", "aspectName": "querySubjects", "aspect": { "json": { "subjects": [ { - "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db_2.table_from_other_db,PROD)" + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_view_on_table,PROD)" }, { - "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD)" + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_view_on_table,PROD),revenue)" } ] } }, "systemMetadata": { - "lastObserved": 1724065178294, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:2957e74d80b00aef4f3dc7b0b323d1fa863c78fd882d858186579c0737df00e2", - "changeType": "UPSERT", - "aspectName": "status", - "aspect": { - "json": { - "removed": false - } - }, - "systemMetadata": { - "lastObserved": 1724064498948, - "runId": "bigquery-queries-2024_08_19-16_18_14", - "lastRunId": "no-run-id-provided" - } -}, -{ - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.destination_table_of_select_query,PROD)", + "entityUrn": "urn:li:query:1796e9c3a125d6474ce2f1fbe1f498d028015b5d7bfd90549dcfcd026826a68f", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -4846,35 +11681,39 @@ }, { "entityType": "query", - "entityUrn": "urn:li:query:f53151fa3d689ec865c53fa535479e3fc3cc5794be5daaa9a5a4f7f40a7c660f", + "entityUrn": "urn:li:query:9e7801810f6e4012bcbe249a5b9e20a5b3582065c09a3563124703315170dce4", "changeType": "UPSERT", - "aspectName": "queryProperties", + "aspectName": "queryUsageStatistics", "aspect": { "json": { - "statement": { - "value": "\n create or replace table `gcp-staging-2.smoke_test_db_3.base_table_2` (date_utc timestamp, revenue INTEGER);\n ", - "language": "SQL" + "timestampMillis": 1724284800000, + "eventGranularity": { + "unit": "DAY", + "multiple": 1 }, - "source": "SYSTEM", - "created": { - "time": 1721549582803, - "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + "partitionSpec": { + "partition": "FULL_TABLE_SNAPSHOT", + "type": "FULL_TABLE" }, - "lastModified": { - "time": 1721549582803, - "actor": "urn:li:corpuser:dh-bigquery-smoke-test" - } + "queryCount": 1, + "uniqueUserCount": 1, + "userCounts": [ + { + "user": "urn:li:corpuser:dh-bigquery-smoke-test", + "count": 1 + } + ] } }, "systemMetadata": { - "lastObserved": 1724065178290, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:a5b8ca0f0b97816db6ca440bdd7c6b11acc823fa70250396b902eb1d46835fbc", + "entityUrn": "urn:li:query:c1c334538a103cfd23352131c5de23677521e78bf74a16021d4877695074c63a", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -4883,120 +11722,151 @@ } }, "systemMetadata": { - "lastObserved": 1724064498951, - "runId": "bigquery-queries-2024_08_19-16_18_14", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:f53151fa3d689ec865c53fa535479e3fc3cc5794be5daaa9a5a4f7f40a7c660f", + "entityUrn": "urn:li:query:c1c334538a103cfd23352131c5de23677521e78bf74a16021d4877695074c63a", "changeType": "UPSERT", - "aspectName": "dataPlatformInstance", + "aspectName": "queryProperties", "aspect": { "json": { - "platform": "urn:li:dataPlatform:bigquery" + "statement": { + "value": "select revenue from gcp-staging.smoke_test_db.view_from_view_on_table", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322533604, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322533604, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } } }, "systemMetadata": { - "lastObserved": 1724065178291, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:f53151fa3d689ec865c53fa535479e3fc3cc5794be5daaa9a5a4f7f40a7c660f", + "entityUrn": "urn:li:query:055def6c8c2745212afa56be1f58fbdc936cd7f37a420a7df6715416fddae4dc", "changeType": "UPSERT", - "aspectName": "querySubjects", + "aspectName": "queryProperties", "aspect": { "json": { - "subjects": [ - { - "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.base_table_2,PROD)" - }, - { - "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.base_table_2,PROD),date_utc)" - }, - { - "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.base_table_2,PROD),revenue)" - } - ] + "statement": { + "value": "select revenue, date_utc from gcp-staging-2.smoke_test_db_4.sharded_table1_20230201", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322560058, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + }, + "lastModified": { + "time": 1724322560058, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test" + } } }, "systemMetadata": { - "lastObserved": 1724065178290, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:4f5fd82d4808115ef07900a543b7d6e3551899815d11a945870c607d2dbda56e", + "entityUrn": "urn:li:query:c1c334538a103cfd23352131c5de23677521e78bf74a16021d4877695074c63a", "changeType": "UPSERT", - "aspectName": "status", + "aspectName": "dataPlatformInstance", "aspect": { "json": { - "removed": false + "platform": "urn:li:dataPlatform:bigquery" } }, "systemMetadata": { - "lastObserved": 1724064498948, - "runId": "bigquery-queries-2024_08_19-16_18_14", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:53d20616e4dd30dfc16ccc5771998f5ed93c9afa9b846104a19d072ba364fb5c", + "entityUrn": "urn:li:query:055def6c8c2745212afa56be1f58fbdc936cd7f37a420a7df6715416fddae4dc", "changeType": "UPSERT", - "aspectName": "status", + "aspectName": "dataPlatformInstance", "aspect": { "json": { - "removed": false + "platform": "urn:li:dataPlatform:bigquery" } }, "systemMetadata": { - "lastObserved": 1724064498949, - "runId": "bigquery-queries-2024_08_19-16_18_14", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.base_table,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:055def6c8c2745212afa56be1f58fbdc936cd7f37a420a7df6715416fddae4dc", "changeType": "UPSERT", - "aspectName": "status", + "aspectName": "querySubjects", "aspect": { "json": { - "removed": false + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD),revenue)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD),date_utc)" + } + ] } }, "systemMetadata": { - "lastObserved": 1724064997314, - "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:bb1e3c0fd1f6a26c2645cf4ba088a22ff346a9e323c6be451459ecfa7329a991", + "entityUrn": "urn:li:query:d326639002bca6c0fe8515dc1599fd1a81f35bbde61806f2fa19487201f7a79f", "changeType": "UPSERT", - "aspectName": "status", + "aspectName": "querySubjects", "aspect": { "json": { - "removed": false + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD),revenue)" + } + ] } }, "systemMetadata": { - "lastObserved": 1724064498952, - "runId": "bigquery-queries-2024_08_19-16_18_14", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:bb3d7f6685e1f71868d0821451e52bfcf1a3bdfeb34c739c0305386256c38f9b", + "entityUrn": "urn:li:query:d326639002bca6c0fe8515dc1599fd1a81f35bbde61806f2fa19487201f7a79f", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5005,62 +11875,81 @@ } }, "systemMetadata": { - "lastObserved": 1724064498952, - "runId": "bigquery-queries-2024_08_19-16_18_14", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_ingestion_time_partition,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:d326639002bca6c0fe8515dc1599fd1a81f35bbde61806f2fa19487201f7a79f", "changeType": "UPSERT", - "aspectName": "status", + "aspectName": "queryProperties", "aspect": { "json": { - "removed": false + "statement": { + "value": "select revenue from gcp-staging-2.smoke_test_db_4.sharded_table1_20230101", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322558514, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322558514, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } } }, "systemMetadata": { - "lastObserved": 1724065178327, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:b66112fa9691aa02354115b5cef8356390b524fa67c6b06e018c362ac8d0b31d", + "entityUrn": "urn:li:query:d326639002bca6c0fe8515dc1599fd1a81f35bbde61806f2fa19487201f7a79f", "changeType": "UPSERT", - "aspectName": "status", + "aspectName": "dataPlatformInstance", "aspect": { "json": { - "removed": false + "platform": "urn:li:dataPlatform:bigquery" } }, "systemMetadata": { - "lastObserved": 1724064498952, - "runId": "bigquery-queries-2024_08_19-16_18_14", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_view_and_table,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:7a4b43ffafd0fb61a647ed56a9383a42fb902f5632a9608c72229ad9da5d4d1c", "changeType": "UPSERT", - "aspectName": "status", + "aspectName": "querySubjects", "aspect": { "json": { - "removed": false + "subjects": [ + { + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_view,PROD)" + }, + { + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_view,PROD),revenue)" + } + ] } }, "systemMetadata": { - "lastObserved": 1724064997317, - "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_multiple_tables,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:7a4b43ffafd0fb61a647ed56a9383a42fb902f5632a9608c72229ad9da5d4d1c", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5069,14 +11958,14 @@ } }, "systemMetadata": { - "lastObserved": 1724064997318, - "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db_2.table_from_other_db,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:039ed54536f1c5bb1ee61f6a6e1f67878c952190620ea30e48768cac208fbe57", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5085,46 +11974,58 @@ } }, "systemMetadata": { - "lastObserved": 1724064997320, - "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_snapshot_on_table,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:7a4b43ffafd0fb61a647ed56a9383a42fb902f5632a9608c72229ad9da5d4d1c", "changeType": "UPSERT", - "aspectName": "status", + "aspectName": "queryProperties", "aspect": { "json": { - "removed": false + "statement": { + "value": "select revenue from gcp-staging.smoke_test_db.table_from_view", + "language": "SQL" + }, + "source": "SYSTEM", + "created": { + "time": 1724322536837, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + }, + "lastModified": { + "time": 1724322536837, + "actor": "urn:li:corpuser:dh-bigquery-smoke-test-2" + } } }, "systemMetadata": { - "lastObserved": 1724064997319, - "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.view_from_table,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:7a4b43ffafd0fb61a647ed56a9383a42fb902f5632a9608c72229ad9da5d4d1c", "changeType": "UPSERT", - "aspectName": "status", + "aspectName": "dataPlatformInstance", "aspect": { "json": { - "removed": false + "platform": "urn:li:dataPlatform:bigquery" } }, "systemMetadata": { - "lastObserved": 1724064997319, - "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:composite_0db44e02f671b69df68565346e9d2b68c7166fccf75bd494f34560bfa16c381b", + "entityUrn": "urn:li:query:f5c935d2377600d41fa76c69b80586aaa0c373b527b9ae46ca62982c53193ad5", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5133,68 +12034,100 @@ } }, "systemMetadata": { - "lastObserved": 1724064997332, - "runId": "bigquery-queries-2024_08_19-16_26_33", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:6bbebdb71c5ef982b74fb6bbef58f7f33162566fd9b14385f2da971503317539", + "entityUrn": "urn:li:query:59c53a03b1fbf71b46518f56b26e7cc3cf03a726567e15cc9d37e6dd2f5c1f60", "changeType": "UPSERT", "aspectName": "querySubjects", "aspect": { "json": { "subjects": [ { - "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_integer_range_partition,PROD)" + "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_view,PROD)" }, { - "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_integer_range_partition,PROD),customer_id)" + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_view,PROD),revenue)" }, { - "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_integer_range_partition,PROD),date1)" + "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_view,PROD),date_utc)" } ] } }, "systemMetadata": { - "lastObserved": 1724065178301, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:6bbebdb71c5ef982b74fb6bbef58f7f33162566fd9b14385f2da971503317539", + "entityUrn": "urn:li:query:59c53a03b1fbf71b46518f56b26e7cc3cf03a726567e15cc9d37e6dd2f5c1f60", + "changeType": "UPSERT", + "aspectName": "status", + "aspect": { + "json": { + "removed": false + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:59c53a03b1fbf71b46518f56b26e7cc3cf03a726567e15cc9d37e6dd2f5c1f60", "changeType": "UPSERT", "aspectName": "queryProperties", "aspect": { "json": { "statement": { - "value": "\n CREATE or REPLACE TABLE `gcp-staging-2.smoke_test_db_4.table_with_integer_range_partition` (customer_id INT64, date1 DATE)\n PARTITION BY\n RANGE_BUCKET(customer_id, GENERATE_ARRAY(0, 100, 10))\n OPTIONS (\n description = \"Description of Integer Range partitioned table\",\n require_partition_filter = TRUE);\n ", + "value": "select revenue, date_utc from gcp-staging.smoke_test_db.table_from_view", "language": "SQL" }, "source": "SYSTEM", "created": { - "time": 1721549596824, + "time": 1724322535333, "actor": "urn:li:corpuser:dh-bigquery-smoke-test" }, "lastModified": { - "time": 1721549596824, + "time": 1724322535333, "actor": "urn:li:corpuser:dh-bigquery-smoke-test" } } }, "systemMetadata": { - "lastObserved": 1724065178301, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:6bbebdb71c5ef982b74fb6bbef58f7f33162566fd9b14385f2da971503317539", + "entityUrn": "urn:li:query:59c53a03b1fbf71b46518f56b26e7cc3cf03a726567e15cc9d37e6dd2f5c1f60", + "changeType": "UPSERT", + "aspectName": "dataPlatformInstance", + "aspect": { + "json": { + "platform": "urn:li:dataPlatform:bigquery" + } + }, + "systemMetadata": { + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", + "lastRunId": "no-run-id-provided" + } +}, +{ + "entityType": "query", + "entityUrn": "urn:li:query:c0552a77514094a5c86fc63041e11a30bcf8985511a85d086695db70939abcc0", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5203,14 +12136,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178339, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.derived_table_from_sharded_table,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:c0182ee336ef4bb9c8e957bc621616573c9aea2a2c0ed08ddd04b1aab2e0ab39", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5219,14 +12152,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178325, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.derived_table,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:32b43422c0184159f4f812fb8e698ed2423a421a7086864aeb11efc3c339246e", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5235,30 +12168,30 @@ } }, "systemMetadata": { - "lastObserved": 1724065178325, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:6bbebdb71c5ef982b74fb6bbef58f7f33162566fd9b14385f2da971503317539", + "entityUrn": "urn:li:query:055def6c8c2745212afa56be1f58fbdc936cd7f37a420a7df6715416fddae4dc", "changeType": "UPSERT", - "aspectName": "dataPlatformInstance", + "aspectName": "status", "aspect": { "json": { - "platform": "urn:li:dataPlatform:bigquery" + "removed": false } }, "systemMetadata": { - "lastObserved": 1724065178301, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_nested_fields,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:82edd8e24a1c289c4c7487b5a3c1b61e4ed6f1c89d5cd2fab5424b085ad0b7d6", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5267,14 +12200,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178328, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:44c19e1fccfa56779f6958f62d3476819b48af701bbee43ccecf5c9e04d63fc4", + "entityUrn": "urn:li:query:fdeaa6e036cca324d7f80811a5f3563986866007bfc7ab1b8bb69515cc38f5f6", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5290,7 +12223,7 @@ }, { "entityType": "query", - "entityUrn": "urn:li:query:f53151fa3d689ec865c53fa535479e3fc3cc5794be5daaa9a5a4f7f40a7c660f", + "entityUrn": "urn:li:query:991a14a8ed8d532c930c8dfd2ace42a7a5fafb76a7a505e14f373e62e8807e0b", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5299,14 +12232,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178346, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_integer_range_partition,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:9e7801810f6e4012bcbe249a5b9e20a5b3582065c09a3563124703315170dce4", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5315,14 +12248,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178328, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:5efacf0ddad8fd852ba394b29e7a4654ea454915930fb8dd4882c6f294b95cf8", + "entityUrn": "urn:li:query:b828588160530bade966b0dbe1c1d09fb3262f6b9137c0956a6f3ed4ef467a91", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5331,14 +12264,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178338, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.derived_table_from_wildcard_table,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:604fa496a50ed8bd340161bebdc475d68daffeaaed31ec649370a2ce392eed90", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5347,65 +12280,46 @@ } }, "systemMetadata": { - "lastObserved": 1724065178326, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:420cad6350235517b34e6e376414d89be0734f87fba6789754be420051d4901c", + "entityUrn": "urn:li:query:1dcc7521d850077c51d832bc4da7c90aa7f4ea89ede1039363082d8db5c23132", "changeType": "UPSERT", - "aspectName": "querySubjects", + "aspectName": "status", "aspect": { "json": { - "subjects": [ - { - "entity": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_ingestion_time_partition,PROD)" - }, - { - "entity": "urn:li:schemaField:(urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.table_with_ingestion_time_partition,PROD),transaction_id)" - } - ] + "removed": false } }, "systemMetadata": { - "lastObserved": 1724065178310, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:420cad6350235517b34e6e376414d89be0734f87fba6789754be420051d4901c", + "entityUrn": "urn:li:query:3989b79902a8974efeffb0c6e2fb5f5e935abd1ce2beb278a876286038a352d0", "changeType": "UPSERT", - "aspectName": "queryProperties", + "aspectName": "status", "aspect": { "json": { - "statement": { - "value": "\n CREATE or REPLACE TABLE\n `gcp-staging-2.smoke_test_db_4.table_with_ingestion_time_partition` (transaction_id INT64)\n PARTITION BY\n _PARTITIONDATE\n OPTIONS (\n description = \"Description of Ingestion time partitioned table\",\n partition_expiration_days = 3,\n require_partition_filter = TRUE);\n ", - "language": "SQL" - }, - "source": "SYSTEM", - "created": { - "time": 1721549596155, - "actor": "urn:li:corpuser:dh-bigquery-smoke-test" - }, - "lastModified": { - "time": 1721549596155, - "actor": "urn:li:corpuser:dh-bigquery-smoke-test" - } + "removed": false } }, "systemMetadata": { - "lastObserved": 1724065178309, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:420cad6350235517b34e6e376414d89be0734f87fba6789754be420051d4901c", + "entityUrn": "urn:li:query:56740f3a3d46afdf0177aadf1dbf4937a4b83c0116aef2773a5de9b7e87895f2", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5414,30 +12328,30 @@ } }, "systemMetadata": { - "lastObserved": 1724065178336, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:420cad6350235517b34e6e376414d89be0734f87fba6789754be420051d4901c", + "entityUrn": "urn:li:query:b5f379bdbfa48c81469b0a5893bb649ba02ff71fcd4ff151675c8728472c9219", "changeType": "UPSERT", - "aspectName": "dataPlatformInstance", + "aspectName": "status", "aspect": { "json": { - "platform": "urn:li:dataPlatform:bigquery" + "removed": false } }, "systemMetadata": { - "lastObserved": 1724065178310, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.customer_demo.purchase_event,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:70d19c139e7fa4f808045ce1b60c3d3a0d9284ae4acc00b5446c27fe1111a6a6", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5446,14 +12360,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178329, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:2fa44cc9d306c7523477fad59ff43e2e580081ee770da69b9b9f66e119b4dcab", + "entityUrn": "urn:li:query:a1dd41eea989d820907358b594b3fb41e0d6812119f5ff657bb02e98dd4c6177", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5462,14 +12376,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178336, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:ccc4a40bb7abb852c9a97a2dc80c0928447bf28b91be0e41a80f691ca8e34e35", + "entityUrn": "urn:li:query:e0e0eb18099d8d8a8ef58c5c7cdaf0948774f0fe02ccd1c1c940b502b69c8483", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5478,14 +12392,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178344, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:6684f16158660588d874f7ac46dbd7e56ad42acfb95b8a3d1f01292de8dcb930", + "entityUrn": "urn:li:query:3ec450841af8056dd02a1f9f059b234119985c2780a30dc38dda726a8b4426dc", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5494,14 +12408,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178339, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.external_table_us_states,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:6422d5a3e23d0bfce3783edc019406cc6cc574044faa5c48edb97cf22294ba33", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5510,14 +12424,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178327, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:2d4a0fdd933c8f9009a21f00b3b0213b025d97ff5e6a39cd031e9d5e5c31f832", + "entityUrn": "urn:li:query:95daf40bccda9fbc9dc15b1109fa105a3c19d83de58625b7265e81cbe8dae940", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5526,14 +12440,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178335, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:88c4674d369ef49e881a5ea67ed3485e48f09b9a4924d5282c3ae25004737f95", + "entityUrn": "urn:li:query:741bb9b00959a800b366a27cd477f8f24292c3b3f0198213c5e06a79b0e00555", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5542,14 +12456,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178340, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.sharded_table1,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:3b9dab2ff83d72565bd19daefcee18b938db280a5c030ccf36fb511f19f929c6", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5558,14 +12472,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178327, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_4.derived_table_from_external_table,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:dd46e45d678f4e7a2755637ac76b97a1d1c723602f767b2fa0f8653920bb8d99", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5574,14 +12488,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178325, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging-2.smoke_test_db_3.base_table_2,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:9b7b2966ae76644cacd808f503c9c5a9d2328e6526fd0b9f4d37fd70fbcf6553", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5590,14 +12504,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178324, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:49b267d0cd050c6a45b4d26bcdc6d9ddceb51aa7ed29399c52ef967e8da2b58d", + "entityUrn": "urn:li:query:c45ca09d68c89c18308b4eb97b2497a1a7c40a21de17b6ea06beab10704a3e3e", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5606,14 +12520,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178337, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:e4e43fe8e17490b4b360a704a5604dd8d55763afd40f10c335e340132a9fe178", + "entityUrn": "urn:li:query:bf9835d210e6e397beb91a558bdf36ecb21f3bca9a4789f1f98d617f0aaaf441", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5622,14 +12536,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178345, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { - "entityType": "dataset", - "entityUrn": "urn:li:dataset:(urn:li:dataPlatform:bigquery,gcp-staging.smoke_test_db.table_from_another_project,PROD)", + "entityType": "query", + "entityUrn": "urn:li:query:aabff37598818c2571a6f1d31137c66ba2a19cae73cc65514a92e703a0b70511", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5638,14 +12552,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178331, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:a049f27174fa88a7a7b1b7d5f60d2c353f3e9dd3d4994a8e35c91adb986eac4d", + "entityUrn": "urn:li:query:f0faa4e0dbe3a28dc69369034ffde5f0cbba1f0a068a1db914bf143dc212aeb6", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5654,14 +12568,14 @@ } }, "systemMetadata": { - "lastObserved": 1724065178341, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } }, { "entityType": "query", - "entityUrn": "urn:li:query:6e250c6966754a5e6532fbb444172dacf5813b0b7afceefbf7772a29878f48f8", + "entityUrn": "urn:li:query:ef372dc8ac2bd484b844e59ea85f81361950f4897a7382df59fb0d4584468fc6", "changeType": "UPSERT", "aspectName": "status", "aspect": { @@ -5670,8 +12584,8 @@ } }, "systemMetadata": { - "lastObserved": 1724065178339, - "runId": "bigquery-queries-2024_08_19-16_29_19", + "lastObserved": 1724050800000, + "runId": "bigquery-queries-2024_08_19-07_00_00", "lastRunId": "no-run-id-provided" } } diff --git a/metadata-ingestion/tests/integration/bigquery_v2/test_bigquery_queries.py b/metadata-ingestion/tests/integration/bigquery_v2/test_bigquery_queries.py index d9effd33f5d278..058a4094fe2fba 100644 --- a/metadata-ingestion/tests/integration/bigquery_v2/test_bigquery_queries.py +++ b/metadata-ingestion/tests/integration/bigquery_v2/test_bigquery_queries.py @@ -6,12 +6,16 @@ import pytest from freezegun import freeze_time +from datahub.ingestion.source.bigquery_v2.bigquery_queries import ( + BigQueryQueriesSourceReport, +) from datahub.sql_parsing.sql_parsing_aggregator import ObservedQuery from datahub.utilities.file_backed_collections import ConnectionWrapper, FileBackedList from tests.test_helpers import mce_helpers from tests.test_helpers.state_helpers import run_and_get_pipeline FROZEN_TIME = "2024-08-19 07:00:00" +WINDOW_END_TIME = "2024-09-01 00:00:00Z" def _generate_queries_cached_file(tmp_path: Path, queries_json_path: Path) -> None: @@ -39,7 +43,7 @@ def test_queries_ingestion(project_client, client, pytestconfig, monkeypatch, tm test_resources_dir = pytestconfig.rootpath / "tests/integration/bigquery_v2" mcp_golden_path = f"{test_resources_dir}/bigquery_queries_mcps_golden.json" - mcp_output_path = "bigquery_queries_mcps.json" + mcp_output_path = tmp_path / "bigquery_queries_mcps.json" try: # query_log.json is originally created by using queries dump generated by @@ -58,14 +62,28 @@ def test_queries_ingestion(project_client, client, pytestconfig, monkeypatch, tm "project_ids": ["gcp-staging", "gcp-staging-2"], "local_temp_path": tmp_path, "top_n_queries": 20, + "window": { + "start_time": "-30d", + "end_time": WINDOW_END_TIME, + }, }, }, - "sink": {"type": "file", "config": {"filename": mcp_output_path}}, + "sink": {"type": "file", "config": {"filename": str(mcp_output_path)}}, } pipeline = run_and_get_pipeline(pipeline_config_dict) pipeline.pretty_print_summary() + report = pipeline.source.get_report() + assert isinstance(report, BigQueryQueriesSourceReport) + assert report.queries_extractor is not None + assert report.queries_extractor.sql_aggregator is not None + assert report.queries_extractor.sql_aggregator.num_query_usage_stats_generated > 0 + assert ( + report.queries_extractor.sql_aggregator.num_query_usage_stats_outside_window + == 0 + ) + mce_helpers.check_golden_file( pytestconfig, output_path=mcp_output_path, From 596de89d70d16b9d0d36b1e21871c9ccc17839a4 Mon Sep 17 00:00:00 2001 From: "dependabot[bot]" <49699333+dependabot[bot]@users.noreply.github.com> Date: Fri, 6 Sep 2024 10:04:10 -0700 Subject: [PATCH 28/34] build(deps): bump micromatch from 4.0.5 to 4.0.8 in /datahub-web-react (#11296) Co-authored-by: dependabot[bot] <49699333+dependabot[bot]@users.noreply.github.com> --- datahub-web-react/yarn.lock | 24 +++++++++++++++++++----- 1 file changed, 19 insertions(+), 5 deletions(-) diff --git a/datahub-web-react/yarn.lock b/datahub-web-react/yarn.lock index 4268acf155de1d..db55cb4f095c08 100644 --- a/datahub-web-react/yarn.lock +++ b/datahub-web-react/yarn.lock @@ -4510,7 +4510,14 @@ brace-expansion@^1.1.7: balanced-match "^1.0.0" concat-map "0.0.1" -braces@^3.0.2, braces@~3.0.2: +braces@^3.0.3: + version "3.0.3" + resolved "https://registry.yarnpkg.com/braces/-/braces-3.0.3.tgz#490332f40919452272d55a8480adc0c441358789" + integrity sha512-yQbXgO/OSZVD2IsiLlro+7Hf6Q18EJrKSEsdoMzKePKXct3gvD8oLcOQdIzGupr5Fj+EDe8gO/lxc1BzfMpxvA== + dependencies: + fill-range "^7.1.1" + +braces@~3.0.2: version "3.0.2" resolved "https://registry.yarnpkg.com/braces/-/braces-3.0.2.tgz#3454e1a462ee8d599e236df336cd9ea4f8afe107" integrity sha512-b8um+L1RzM3WDSzvhm6gIz1yfTbBt6YTlcEKAvsmqCZZFw46z626lVj9j1yEPW33H5H+lBQpZMP1k8l+78Ha0A== @@ -6052,6 +6059,13 @@ fill-range@^7.0.1: dependencies: to-regex-range "^5.0.1" +fill-range@^7.1.1: + version "7.1.1" + resolved "https://registry.yarnpkg.com/fill-range/-/fill-range-7.1.1.tgz#44265d3cac07e3ea7dc247516380643754a05292" + integrity sha512-YsGpe3WHLK8ZYi4tWDg2Jy3ebRz2rXowDxnld4bkQB00cc/1Zw9AWnC0i9ztDJitivtQvaI9KaLyKrc+hBW0yg== + dependencies: + to-regex-range "^5.0.1" + filter-obj@^1.1.0: version "1.1.0" resolved "https://registry.yarnpkg.com/filter-obj/-/filter-obj-1.1.0.tgz#9b311112bc6c6127a16e016c6c5d7f19e0805c5b" @@ -7654,11 +7668,11 @@ micromark@^2.11.3, micromark@~2.11.0, micromark@~2.11.3: parse-entities "^2.0.0" micromatch@^4.0.4, micromatch@^4.0.5: - version "4.0.5" - resolved "https://registry.yarnpkg.com/micromatch/-/micromatch-4.0.5.tgz#bc8999a7cbbf77cdc89f132f6e467051b49090c6" - integrity sha512-DMy+ERcEW2q8Z2Po+WNXuw3c5YaUSFjAO5GsJqfEl7UjvtIuFKO6ZrKvcItdy98dwFI2N1tg3zNIdKaQT+aNdA== + version "4.0.8" + resolved "https://registry.yarnpkg.com/micromatch/-/micromatch-4.0.8.tgz#d66fa18f3a47076789320b9b1af32bd86d9fa202" + integrity sha512-PXwfBhYu0hBCPw8Dn0E+WDYb7af3dSLVWKi3HGv84IdF4TyFoC0ysxFd0Goxw7nSv4T/PzEJQxsYsEiFCKo2BA== dependencies: - braces "^3.0.2" + braces "^3.0.3" picomatch "^2.3.1" mime-db@1.52.0: From 0ce9e946a6d3f28f7a0f82d0f918170a5e47be1d Mon Sep 17 00:00:00 2001 From: John Joyce Date: Fri, 6 Sep 2024 15:30:16 -0700 Subject: [PATCH 29/34] fix(docs): Add correct link for automations (#11323) Co-authored-by: John Joyce --- docs-website/sidebars.js | 4 ++-- docs/{automation => automations}/docs-propagation.md | 0 docs/{automation => automations}/snowflake-tag-propagation.md | 0 3 files changed, 2 insertions(+), 2 deletions(-) rename docs/{automation => automations}/docs-propagation.md (100%) rename docs/{automation => automations}/snowflake-tag-propagation.md (100%) diff --git a/docs-website/sidebars.js b/docs-website/sidebars.js index 0382f821a31ca3..fe1ee9e6236ab7 100644 --- a/docs-website/sidebars.js +++ b/docs-website/sidebars.js @@ -105,12 +105,12 @@ module.exports = { { label: "Documentation Propagation", type: "doc", - id: "docs/automation/docs-propagation", + id: "docs/automations/docs-propagation", }, { label: "Snowflake Tag Sync", type: "doc", - id: "docs/automation/snowflake-tag-propagation", + id: "docs/automations/snowflake-tag-propagation", className: "saasOnly", }, ], diff --git a/docs/automation/docs-propagation.md b/docs/automations/docs-propagation.md similarity index 100% rename from docs/automation/docs-propagation.md rename to docs/automations/docs-propagation.md diff --git a/docs/automation/snowflake-tag-propagation.md b/docs/automations/snowflake-tag-propagation.md similarity index 100% rename from docs/automation/snowflake-tag-propagation.md rename to docs/automations/snowflake-tag-propagation.md From 607ad5e1bc5190c859a3c3eeba33253d46092247 Mon Sep 17 00:00:00 2001 From: Harshal Sheth Date: Fri, 6 Sep 2024 15:32:25 -0700 Subject: [PATCH 30/34] feat(cli): reject missing urns in `datahub get` (#11313) --- docs/how/updating-datahub.md | 2 ++ metadata-ingestion/src/datahub/cli/get_cli.py | 28 +++++++++++++------ 2 files changed, 22 insertions(+), 8 deletions(-) diff --git a/docs/how/updating-datahub.md b/docs/how/updating-datahub.md index 293e39e735e013..dbf2d4a0c5169a 100644 --- a/docs/how/updating-datahub.md +++ b/docs/how/updating-datahub.md @@ -31,6 +31,8 @@ This file documents any backwards-incompatible changes in DataHub and assists pe ``` Re-running with stateful ingestion should automatically clear up the entities with old URNS and add entities with new URNs, therefore not duplicating the containers or jobs. +- #11313 - `datahub get` will no longer return a key aspect for entities that don't exist. + ### Potential Downtime ### Deprecations diff --git a/metadata-ingestion/src/datahub/cli/get_cli.py b/metadata-ingestion/src/datahub/cli/get_cli.py index 27fa987ac79779..ab31323ac52b6f 100644 --- a/metadata-ingestion/src/datahub/cli/get_cli.py +++ b/metadata-ingestion/src/datahub/cli/get_cli.py @@ -48,16 +48,28 @@ def urn(ctx: Any, urn: Optional[str], aspect: List[str], details: bool) -> None: client = get_default_graph() + if aspect: + # If aspects are specified, we need to do the existence check first. + if not client.exists(urn): + raise click.ClickException(f"urn {urn} not found") + + aspect_data = get_aspects_for_entity( + session=client._session, + gms_host=client.config.server, + entity_urn=urn, + aspects=aspect, + typed=False, + details=details, + ) + + if not aspect: + # If no aspects are specified and we only get a key aspect back, yield an error instead. + if len(aspect_data) == 1 and "key" in next(iter(aspect_data)).lower(): + raise click.ClickException(f"urn {urn} not found") + click.echo( json.dumps( - get_aspects_for_entity( - session=client._session, - gms_host=client.config.server, - entity_urn=urn, - aspects=aspect, - typed=False, - details=details, - ), + aspect_data, sort_keys=True, indent=2, ) From 80f493acdad994340a709a522ab0543c57fe1b6e Mon Sep 17 00:00:00 2001 From: Harshal Sheth Date: Sun, 8 Sep 2024 04:59:58 -0700 Subject: [PATCH 31/34] fix(smoke): fix timeseries delete test's usage of `datahub get` (#11330) --- smoke-test/build.gradle | 2 +- smoke-test/smoke.sh | 2 +- .../cli/delete_cmd/test_timeseries_delete.py | 18 +++++++++++------- 3 files changed, 13 insertions(+), 9 deletions(-) diff --git a/smoke-test/build.gradle b/smoke-test/build.gradle index a9e5a8942b71ec..eb9ab7dec8f6cc 100644 --- a/smoke-test/build.gradle +++ b/smoke-test/build.gradle @@ -64,7 +64,7 @@ task installDev(type: Exec) { commandLine 'bash', '-c', "set -x && " + "${python_executable} -m venv ${venv_name} && " + - "${venv_name}/bin/python -m pip install --upgrade pip uv wheel setuptools && " + + "${venv_name}/bin/python -m pip install --upgrade uv && " + "set +x && source ${venv_name}/bin/activate && set -x && " + "uv pip install -r requirements.txt && " + "touch ${venv_name}/.build_install_dev_sentinel" diff --git a/smoke-test/smoke.sh b/smoke-test/smoke.sh index d74f77a4e624a1..888a60f488e1fc 100755 --- a/smoke-test/smoke.sh +++ b/smoke-test/smoke.sh @@ -23,7 +23,7 @@ else python3 -m venv venv source venv/bin/activate - python -m pip install --upgrade pip 'uv>=0.1.10' wheel setuptools + python -m pip install --upgrade 'uv>=0.1.10' uv pip install -r requirements.txt fi diff --git a/smoke-test/tests/cli/delete_cmd/test_timeseries_delete.py b/smoke-test/tests/cli/delete_cmd/test_timeseries_delete.py index cfbbacea1ed79e..438c063f11fa88 100644 --- a/smoke-test/tests/cli/delete_cmd/test_timeseries_delete.py +++ b/smoke-test/tests/cli/delete_cmd/test_timeseries_delete.py @@ -56,16 +56,20 @@ def datahub_get_and_verify_profile( sync_elastic() get_args: List[str] = ["get", "--urn", test_dataset_urn, "-a", test_aspect_name] get_result: Result = runner.invoke(datahub, get_args) - assert get_result.exit_code == 0 - try: - get_result_output_obj: Dict = json.loads(get_result.stdout) - except JSONDecodeError as e: - print("Failed to decode: " + get_result.stdout, file=sys.stderr) - raise e if expected_profile is None: - assert not get_result_output_obj + assert get_result.exit_code != 0 + assert ( + test_dataset_urn in get_result.stderr and "not found" in get_result.stderr + ), f"Got stderr of {get_result.stderr} in get_and_verify_profile" else: + assert get_result.exit_code == 0 + try: + get_result_output_obj: Dict = json.loads(get_result.stdout) + except JSONDecodeError as e: + print("Failed to decode: " + get_result.stdout, file=sys.stderr) + raise e + profile_from_get = DatasetProfileClass.from_obj( get_result_output_obj["datasetProfile"] ) From d0bad4a7eeca8025eb423e8efca9617277c814c3 Mon Sep 17 00:00:00 2001 From: Harshal Sheth Date: Sun, 8 Sep 2024 11:07:18 -0700 Subject: [PATCH 32/34] feat(ingest): make rest emitter version error messages more clear (#11295) --- .../src/datahub/emitter/rest_emitter.py | 19 ++++++++++++++----- 1 file changed, 14 insertions(+), 5 deletions(-) diff --git a/metadata-ingestion/src/datahub/emitter/rest_emitter.py b/metadata-ingestion/src/datahub/emitter/rest_emitter.py index db4f1749d85446..f4bc3666a18c82 100644 --- a/metadata-ingestion/src/datahub/emitter/rest_emitter.py +++ b/metadata-ingestion/src/datahub/emitter/rest_emitter.py @@ -307,12 +307,21 @@ def _emit_generic(self, url: str, payload: str) -> None: except HTTPError as e: try: info: Dict = response.json() - logger.debug( - "Full stack trace from DataHub:\n%s", info.get("stackTrace") - ) - info.pop("stackTrace", None) + + if info.get("stackTrace"): + logger.debug( + "Full stack trace from DataHub:\n%s", info.get("stackTrace") + ) + info.pop("stackTrace", None) + + hint = "" + if "unrecognized field found but not allowed" in ( + info.get("message") or "" + ): + hint = ", likely because the server version is too old relative to the client" + raise OperationalError( - f"Unable to emit metadata to DataHub GMS: {info.get('message')}", + f"Unable to emit metadata to DataHub GMS{hint}: {info.get('message')}", info, ) from e except JSONDecodeError: From 9b64b117c7f9729169e844e3111cf5bcfa8893b5 Mon Sep 17 00:00:00 2001 From: Harshal Sheth Date: Mon, 9 Sep 2024 00:01:46 -0700 Subject: [PATCH 33/34] docs(ingest/dbt): clarify dbt ingestion docs (#11312) --- metadata-ingestion/docs/sources/dbt/README.md | 24 ++++++++++--------- .../ingestion/source/aws/aws_common.py | 2 +- 2 files changed, 14 insertions(+), 12 deletions(-) diff --git a/metadata-ingestion/docs/sources/dbt/README.md b/metadata-ingestion/docs/sources/dbt/README.md index c7aea8db38d6de..ab262f2197cc0d 100644 --- a/metadata-ingestion/docs/sources/dbt/README.md +++ b/metadata-ingestion/docs/sources/dbt/README.md @@ -2,17 +2,19 @@ Ingesting metadata from dbt requires either using the **dbt** module or the **db ### Concept Mapping -| Source Concept | DataHub Concept | Notes | -| --------------- | ------------------------------------------------------------- | ------------------ | -| `"dbt"` | [Data Platform](../../metamodel/entities/dataPlatform.md) | | -| dbt Source | [Dataset](../../metamodel/entities/dataset.md) | Subtype `Source` | -| dbt Seed | [Dataset](../../metamodel/entities/dataset.md) | Subtype `Seed` | -| dbt Model | [Dataset](../../metamodel/entities/dataset.md) | Subtype `Model` | -| dbt Snapshot | [Dataset](../../metamodel/entities/dataset.md) | Subtype `Snapshot` | -| dbt Test | [Assertion](../../metamodel/entities/assertion.md) | | -| dbt Test Result | [Assertion Run Result](../../metamodel/entities/assertion.md) | | +| Source Concept | DataHub Concept | Notes | +| -------------- | ---------------------------------------------------------------------- | ------------------ | +| Source | [Dataset](../../metamodel/entities/dataset.md) | Subtype `Source` | +| Seed | [Dataset](../../metamodel/entities/dataset.md) | Subtype `Seed` | +| Model | [Dataset](../../metamodel/entities/dataset.md) | Subtype `Model` | +| Snapshot | [Dataset](../../metamodel/entities/dataset.md) | Subtype `Snapshot` | +| Test | [Assertion](../../metamodel/entities/assertion.md) | | +| Test Result | [Assertion Run Result](../../metamodel/entities/assertion.md) | | +| Model Runs | [DataProcessInstance](../../metamodel/entities/dataProcessInstance.md) | | Note: -1. It also generates lineage between the `dbt` nodes (e.g. ephemeral nodes that depend on other dbt sources) as well as lineage between the `dbt` nodes and the underlying (target) platform nodes (e.g. BigQuery Table -> dbt Source, dbt View -> BigQuery View). -2. We also support automated actions (like add a tag, term or owner) based on properties defined in dbt meta. +1. You must **run ingestion for both dbt and your data warehouse** (target platform). They can be run in any order. +2. It generates column lineage between the `dbt` nodes (e.g. when a model/snapshot depends on a dbt source or ephemeral model) as well as lineage between the `dbt` nodes and the underlying target platform nodes (e.g. BigQuery Table -> dbt source, dbt model -> BigQuery table/view). +3. It automatically generates "sibling" relationships between the dbt nodes and the target / data warehouse nodes. These nodes will show up in the UI with both platform logos. +4. We also support automated actions (like add a tag, term or owner) based on properties defined in dbt meta. diff --git a/metadata-ingestion/src/datahub/ingestion/source/aws/aws_common.py b/metadata-ingestion/src/datahub/ingestion/source/aws/aws_common.py index 6eb02fe80552ec..ce45a5c9b95dcc 100644 --- a/metadata-ingestion/src/datahub/ingestion/source/aws/aws_common.py +++ b/metadata-ingestion/src/datahub/ingestion/source/aws/aws_common.py @@ -91,7 +91,7 @@ class AwsConnectionConfig(ConfigModel): aws_role: Optional[Union[str, List[Union[str, AwsAssumeRoleConfig]]]] = Field( default=None, description="AWS roles to assume. If using the string format, the role ARN can be specified directly. " - "If using the object format, the role can be specified in the RoleArn field and additional available arguments are documented at https://boto3.amazonaws.com/v1/documentation/api/latest/reference/services/sts.html?highlight=assume_role#STS.Client.assume_role", + "If using the object format, the role can be specified in the RoleArn field and additional available arguments are the same as [boto3's STS.Client.assume_role](https://boto3.amazonaws.com/v1/documentation/api/latest/reference/services/sts.html?highlight=assume_role#STS.Client.assume_role).", ) aws_profile: Optional[str] = Field( default=None, From 5467481f167115c9f59438837e667e0d333218ac Mon Sep 17 00:00:00 2001 From: Harshal Sheth Date: Mon, 9 Sep 2024 00:02:05 -0700 Subject: [PATCH 34/34] fix(py): fix issues with AvroException (#11311) --- metadata-ingestion/setup.py | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/metadata-ingestion/setup.py b/metadata-ingestion/setup.py index cbe3a6c250c1e7..6f0fce4d271020 100644 --- a/metadata-ingestion/setup.py +++ b/metadata-ingestion/setup.py @@ -36,7 +36,7 @@ "importlib_metadata>=4.0.0; python_version < '3.10'", "docker", "expandvars>=0.6.5", - "avro-gen3==0.7.13", + "avro-gen3==0.7.16", # "avro-gen3 @ git+https://github.com/acryldata/avro_gen@master#egg=avro-gen3", "avro>=1.11.3,<1.12", "python-dateutil>=2.8.0",