diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/parallel.py b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/parallel.py index a8a04a6859d0..cdbe47340864 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/parallel.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/_internal/entities/parallel.py @@ -24,6 +24,7 @@ def __init__(self, **kwargs): self._max_concurrency_per_instance = kwargs.pop("max_concurrency_per_instance", None) self._error_threshold = kwargs.pop("error_threshold", None) self._mini_batch_size = kwargs.pop("mini_batch_size", None) + self._partition_keys = kwargs.pop("partition_keys", None) self._logging_level = kwargs.pop("logging_level", None) self._retry_settings = kwargs.pop("retry_settings", BatchRetrySettings()) self._init = False @@ -60,6 +61,15 @@ def mini_batch_size(self) -> int: def mini_batch_size(self, value: int): self._mini_batch_size = value + @property + def partition_keys(self) -> List: + """The keys used to partition dataset into mini-batches.""" + return self._partition_keys + + @partition_keys.setter + def partition_keys(self, value: List): + self._partition_keys = value + @property def logging_level(self) -> str: """A string of the logging level name""" diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/component/parallel_component.py b/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/component/parallel_component.py index d4d2f96789b1..f7b236153b3a 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/component/parallel_component.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/component/parallel_component.py @@ -35,6 +35,11 @@ class ParallelComponentSchema(ComponentSchema): mini_batch_size = fields.Str( metadata={"description": "The The batch size of current job."}, ) + partition_keys = fields.List( + fields.Str(), + metadata={"description": "The keys used to partition input data into mini-batches"} + ) + input_data = fields.Str() retry_settings = NestedField(RetrySettingsSchema, unknown=INCLUDE) max_concurrency_per_instance = fields.Integer( diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/job/parameterized_parallel.py b/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/job/parameterized_parallel.py index e186cb136dcb..7e204e8bdd48 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/job/parameterized_parallel.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/_schema/job/parameterized_parallel.py @@ -28,6 +28,10 @@ class ParameterizedParallelSchema(PathAwareSchema): mini_batch_size = fields.Str( metadata={"description": "The batch size of current job."}, ) + partition_keys = fields.List( + fields.Str(), + metadata={"description": "The keys used to partition input data into mini-batches"} + ) input_data = fields.Str() resources = NestedField(JobResourceConfigurationSchema) retry_settings = NestedField(RetrySettingsSchema, unknown=INCLUDE) diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_builders/parallel.py b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_builders/parallel.py index 7290ee61d552..cd3494f35f5c 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_builders/parallel.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_builders/parallel.py @@ -7,6 +7,7 @@ import copy import logging import re +import json from enum import Enum from typing import Dict, List, Union @@ -69,6 +70,12 @@ class Parallel(BaseNode): (optional, default value is 10 files for FileDataset and 1MB for TabularDataset.) This value could be set through PipelineParameter :type mini_batch_size: str + :param partition_keys: The keys used to partition dataset into mini-batches. + If specified, the data with the same key will be partitioned into the same mini-batch. + If both partition_keys and mini_batch_size are specified, the partition keys will take effect. + The input(s) must be partitioned dataset(s), + and the partition_keys must be a subset of the keys of every input dataset for this to work. + :type partition_keys: List :param input_data: The input data. :type input_data: str :param inputs: Inputs of the component/job. @@ -104,6 +111,7 @@ def __init__( mini_batch_error_threshold: int = None, input_data: str = None, task: Dict[str, Union[ParallelTask, str]] = None, + partition_keys: List = None, mini_batch_size: int = None, resources: JobResourceConfiguration = None, environment_variables: Dict = None, @@ -147,6 +155,7 @@ def __init__( raise ValueError("mini_batch_size unit must be kb, mb or gb") self.mini_batch_size = mini_batch_size + self.partition_keys = partition_keys self.input_data = input_data self._retry_settings = retry_settings self.logging_level = logging_level @@ -166,6 +175,8 @@ def __init__( self.mini_batch_error_threshold or self.component.mini_batch_error_threshold ) self.mini_batch_size = self.mini_batch_size or self.component.mini_batch_size + self.partition_keys = self.partition_keys or self.component.partition_keys + if not self.task: self.task = self.component.task # task.code is based on self.component.base_path @@ -270,6 +281,7 @@ def _to_job(self) -> ParallelJob: properties=self.properties, compute=self.compute, resources=self.resources, + partition_keys=self.partition_keys, mini_batch_size=self.mini_batch_size, task=self.task, retry_settings=self.retry_settings, @@ -318,6 +330,8 @@ def _to_rest_object(self, **kwargs) -> dict: retry_settings=get_rest_dict_for_node_attrs(self.retry_settings), logging_level=self.logging_level, mini_batch_size=self.mini_batch_size, + partition_keys=json.dumps(self.partition_keys) + if self.partition_keys is not None else self.partition_keys, resources=get_rest_dict_for_node_attrs(self.resources), ) ) @@ -353,7 +367,8 @@ def _from_rest_object(cls, obj: dict) -> "Parallel": # distribution, sweep won't have distribution if "distribution" in obj and obj["distribution"]: obj["distribution"] = DistributionConfiguration._from_rest_object(obj["distribution"]) - + if "partition_keys" in obj and obj["partition_keys"]: + obj["partition_keys"] = json.dumps(obj["partition_keys"]) return Parallel(**obj) def _build_inputs(self): @@ -392,6 +407,7 @@ def __call__(self, *args, **kwargs) -> "Parallel": node.tags = self.tags node.display_name = self.display_name node.mini_batch_size = self.mini_batch_size + node.partition_keys = self.partition_keys node.logging_level = self.logging_level node.max_concurrency_per_instance = self.max_concurrency_per_instance node.error_threshold = self.error_threshold diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_builders/parallel_func.py b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_builders/parallel_func.py index f212a350559b..4dbca29848a7 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_builders/parallel_func.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_builders/parallel_func.py @@ -2,7 +2,7 @@ # Copyright (c) Microsoft Corporation. All rights reserved. # --------------------------------------------------------- import os -from typing import Dict, Union +from typing import Dict, Union, List from azure.ai.ml._restclient.v2022_02_01_preview.models import AmlToken, ManagedIdentity from azure.ai.ml.constants._component import ComponentSource @@ -31,6 +31,7 @@ def parallel_run_function( mini_batch_error_threshold: int = None, task: RunFunction = None, mini_batch_size: str = None, + partition_keys: List = None, input_data: str = None, inputs: Dict = None, outputs: Dict = None, @@ -136,6 +137,12 @@ def parallel_run_function( (optional, default value is 10 files for FileDataset and 1MB for TabularDataset.) This value could be set through PipelineParameter. :type mini_batch_size: str + :param partition_keys: The keys used to partition dataset into mini-batches. + If specified, the data with the same key will be partitioned into the same mini-batch. + If both partition_keys and mini_batch_size are specified, the partition keys will take effect. + The input(s) must be partitioned dataset(s), + and the partition_keys must be a subset of the keys of every input dataset for this to work. + :type partition_keys: List :param input_data: The input data. :type input_data: str :param inputs: a dict of inputs used by this parallel. @@ -190,6 +197,7 @@ def parallel_run_function( mini_batch_error_threshold=mini_batch_error_threshold, task=task, mini_batch_size=mini_batch_size, + partition_keys=partition_keys, input_data=input_data, _source=ComponentSource.BUILDER, is_deterministic=is_deterministic, @@ -216,6 +224,7 @@ def parallel_run_function( mini_batch_error_threshold=mini_batch_error_threshold, task=task, mini_batch_size=mini_batch_size, + partition_keys=partition_keys, input_data=input_data, **kwargs, ) diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_component/component_factory.py b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_component/component_factory.py index 91b8c41152fc..269a443ecf20 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_component/component_factory.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_component/component_factory.py @@ -183,6 +183,11 @@ def load_from_rest(self, *, obj: ComponentVersionData, _type: str = None) -> Com if distribution: distribution = DistributionConfiguration._from_rest_object(distribution) + if _type == "parallel": + import json + if "partition_keys" in rest_component_version.component_spec: + rest_component_version.component_spec["partition_keys"] \ + = json.loads(rest_component_version.component_spec["partition_keys"]) # Note: we need to refine the logic here if more specific type logic here. jobs = rest_component_version.component_spec.pop("jobs", None) if _type == NodeType.PIPELINE and jobs: diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_component/parallel_component.py b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_component/parallel_component.py index fc5e12de4c9d..1600595a6f93 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_component/parallel_component.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_component/parallel_component.py @@ -4,7 +4,8 @@ import os import re -from typing import Any, Dict, Union +import json +from typing import Any, Dict, Union, List from marshmallow import Schema @@ -16,9 +17,10 @@ from azure.ai.ml.entities._job.parallel.parameterized_parallel import ParameterizedParallel from azure.ai.ml.entities._job.parallel.retry_settings import RetrySettings from azure.ai.ml.exceptions import ErrorCategory, ErrorTarget, ValidationException +from azure.ai.ml._restclient.v2022_05_01.models import ComponentVersionData from ..._schema import PathAwareSchema -from .._util import convert_ordered_dict_to_dict, validate_attribute_type +from .._util import validate_attribute_type from .component import Component @@ -53,6 +55,12 @@ class ParallelComponent(Component, ParameterizedParallel): # pylint: disable=to (optional, default value is 10 files for FileDataset and 1MB for TabularDataset.) This value could be set through PipelineParameter. :type mini_batch_size: str + :param partition_keys: The keys used to partition dataset into mini-batches. + If specified, the data with the same key will be partitioned into the same mini-batch. + If both partition_keys and mini_batch_size are specified, partition_keys will take effect. + The input(s) must be partitioned dataset(s), + and the partition_keys must be a subset of the keys of every input dataset for this to work. + :type partition_keys: list :param input_data: The input data. :type input_data: str :param resources: Compute Resource configuration for the component. @@ -86,6 +94,7 @@ def __init__( mini_batch_error_threshold: int = None, task: ParallelTask = None, mini_batch_size: str = None, + partition_keys: List = None, input_data: str = None, resources: JobResourceConfiguration = None, inputs: Dict = None, @@ -116,6 +125,7 @@ def __init__( # and fill in later with job defaults. self.task = task self.mini_batch_size = mini_batch_size + self.partition_keys = partition_keys self.input_data = input_data self.retry_settings = retry_settings self.logging_level = logging_level @@ -225,9 +235,12 @@ def _attr_type_map(cls) -> dict: "resources": (dict, JobResourceConfiguration), } - def _to_dict(self) -> Dict: - """Dump the parallel component content into a dictionary.""" - return convert_ordered_dict_to_dict({**self._other_parameter, **super(ParallelComponent, self)._to_dict()}) + def _to_rest_object(self) -> ComponentVersionData: + rest_object = super()._to_rest_object() + if self.partition_keys: + rest_object.properties.component_spec["partition_keys"]= \ + json.dumps(self.partition_keys) + return rest_object @classmethod def _create_schema_for_validation(cls, context) -> Union[PathAwareSchema, Schema]: diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_job/parallel/parallel_job.py b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_job/parallel/parallel_job.py index 53aa6f73e987..3f647249cee0 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_job/parallel/parallel_job.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_job/parallel/parallel_job.py @@ -54,6 +54,8 @@ class ParallelJob(Job, ParameterizedParallel, JobIOMixin): :type task: ParallelTask :param mini_batch_size: The mini batch size. :type mini_batch_size: str + :param partition_keys: The partition keys. + :type partition_keys: list :param input_data: The input data. :type input_data: str :param inputs: Inputs of the job. @@ -107,6 +109,7 @@ def _to_component(self, context: Dict = None, **kwargs): return ParallelComponent( base_path=context[BASE_PATH_CONTEXT_KEY], mini_batch_size=self.mini_batch_size, + partition_keys=self.partition_keys, input_data=self.input_data, task=self.task, retry_settings=self.retry_settings, @@ -137,6 +140,7 @@ def _to_node(self, context: Dict = None, **kwargs): inputs=self.inputs, outputs=self.outputs, mini_batch_size=self.mini_batch_size, + partition_keys=self.partition_keys, input_data=self.input_data, # task will be inherited from component & base_path will be set correctly. retry_settings=self.retry_settings, diff --git a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_job/parallel/parameterized_parallel.py b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_job/parallel/parameterized_parallel.py index d99219be43ff..d15f12503d19 100644 --- a/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_job/parallel/parameterized_parallel.py +++ b/sdk/ml/azure-ai-ml/azure/ai/ml/entities/_job/parallel/parameterized_parallel.py @@ -3,7 +3,7 @@ # --------------------------------------------------------- import logging -from typing import Dict, Union +from typing import Dict, Union, List from ..job_resource_configuration import JobResourceConfiguration from .parallel_task import ParallelTask @@ -47,10 +47,12 @@ def __init__( input_data: str = None, task: ParallelTask = None, mini_batch_size: int = None, + partition_keys: List = None, resources: Union[dict, JobResourceConfiguration] = None, environment_variables: Dict = None, ): self.mini_batch_size = mini_batch_size + self.partition_keys = partition_keys self.task = task self.retry_settings = retry_settings self.input_data = input_data diff --git a/sdk/ml/azure-ai-ml/tests/component/unittests/test_parallel_component_entity.py b/sdk/ml/azure-ai-ml/tests/component/unittests/test_parallel_component_entity.py index 68c04715b4f7..c0aa57f68fa2 100644 --- a/sdk/ml/azure-ai-ml/tests/component/unittests/test_parallel_component_entity.py +++ b/sdk/ml/azure-ai-ml/tests/component/unittests/test_parallel_component_entity.py @@ -99,6 +99,7 @@ def test_parallel_component_version_as_a_function_with_inputs(self): "error_threshold": None, "logging_level": None, "max_concurrency_per_instance": None, + "partition_keys": None, "mini_batch_error_threshold": None, "mini_batch_size": 10485760, "retry_settings": None, diff --git a/sdk/ml/azure-ai-ml/tests/component/unittests/test_parallel_component_schema.py b/sdk/ml/azure-ai-ml/tests/component/unittests/test_parallel_component_schema.py index cf8c495d8309..4696ad72a485 100644 --- a/sdk/ml/azure-ai-ml/tests/component/unittests/test_parallel_component_schema.py +++ b/sdk/ml/azure-ai-ml/tests/component/unittests/test_parallel_component_schema.py @@ -112,3 +112,30 @@ def test_serialize_deserialize_basic(self, mock_machinelearning_client: MLClient assert component_entity.code assert component_entity.code == f"{str(Path('./tests/test_configs/python').resolve())}:1" + + def test_serialize_deserialize_partition_keys(self, mock_machinelearning_client: MLClient): + test_path = "./tests/test_configs/components/parallel_component_with_partition_keys.yml" + component_entity = load_component_entity_from_yaml(test_path, mock_machinelearning_client) + rest_path = "./tests/test_configs/components/parallel_component_with_partition_keys_rest.json" + target_entity = load_component_entity_from_rest_json(rest_path) + + # skip check code and environment + component_dict = component_entity._to_dict() + assert component_dict["id"] + component_dict = pydash.omit( + dict(component_dict), + "task.code", + "id", + ) + expected_dict = pydash.omit( + dict(target_entity._to_dict()), + "task.code", + "creation_context", + "id", + ) + + assert component_dict == expected_dict + assert component_dict["partition_keys"] == ["foo", "bar"] + + assert component_entity.code + assert component_entity.code == f"{str(Path('./tests/test_configs/python').resolve())}:1" diff --git a/sdk/ml/azure-ai-ml/tests/dsl/e2etests/test_dsl_pipeline.py b/sdk/ml/azure-ai-ml/tests/dsl/e2etests/test_dsl_pipeline.py index 926f36339a3b..39f67160bbab 100644 --- a/sdk/ml/azure-ai-ml/tests/dsl/e2etests/test_dsl_pipeline.py +++ b/sdk/ml/azure-ai-ml/tests/dsl/e2etests/test_dsl_pipeline.py @@ -1726,6 +1726,7 @@ def parallel_in_pipeline(job_data_path): }, "name": "node1", "mini_batch_size": 5, + "partition_keys": None, "retry_settings": None, "logging_level": "DEBUG", "max_concurrency_per_instance": 1, @@ -1945,6 +1946,7 @@ def parallel_in_pipeline(job_data_path): }, "outputs": {}, "mini_batch_size": 1, + "partition_keys": None, "task": { "type": "run_function", "entry_script": "score.py", @@ -1992,6 +1994,7 @@ def parallel_in_pipeline(job_data_path): }, "outputs": {"job_output_path": {"value": "${{parent.outputs.job_out_data}}", "type": "literal"}}, "mini_batch_size": 1, + "partition_keys": None, "task": { "type": "run_function", "entry_script": "score.py", diff --git a/sdk/ml/azure-ai-ml/tests/dsl/unittests/test_dsl_pipeline_with_specific_nodes.py b/sdk/ml/azure-ai-ml/tests/dsl/unittests/test_dsl_pipeline_with_specific_nodes.py index b36708b03210..444855ebcdf2 100644 --- a/sdk/ml/azure-ai-ml/tests/dsl/unittests/test_dsl_pipeline_with_specific_nodes.py +++ b/sdk/ml/azure-ai-ml/tests/dsl/unittests/test_dsl_pipeline_with_specific_nodes.py @@ -1133,6 +1133,7 @@ def pipeline(job_data_path): }, "resources": {"instance_count": 2, "properties": {}}, "mini_batch_size": 5, + "partition_keys": None, "retry_settings": None, "logging_level": None, "max_concurrency_per_instance": 1, @@ -1240,6 +1241,7 @@ def pipeline(path): }, "resources": {"instance_count": 2, "properties": {}}, "mini_batch_size": 5, + "partition_keys": None, "task": { "type": "run_function", "code": "./tests/test_configs/dsl_pipeline/parallel_component_with_file_input/src/", @@ -1274,6 +1276,7 @@ def pipeline(path): }, "resources": {"instance_count": 2, "properties": {}}, "mini_batch_size": 5, + "partition_keys": None, "task": { "type": "run_function", "code": "./tests/test_configs/dsl_pipeline/parallel_component_with_file_input/src/", @@ -1466,6 +1469,7 @@ def parallel_in_pipeline(job_data_path): }, "outputs": {}, "mini_batch_size": 1, + "partition_keys": None, "task": { "program_arguments": "--job_output_path " "${{outputs.job_output_path}}", "code": "./src", @@ -1517,6 +1521,7 @@ def parallel_in_pipeline(job_data_path): }, "outputs": {"job_output_path": {"value": "${{parent.outputs.job_out_data}}", "type": "literal"}}, "mini_batch_size": 1, + "partition_keys": None, "task": { "program_arguments": "--job_output_path " "${{outputs.job_output_path}}", "code": "./src", diff --git a/sdk/ml/azure-ai-ml/tests/pipeline_job/e2etests/test_pipeline_job.py b/sdk/ml/azure-ai-ml/tests/pipeline_job/e2etests/test_pipeline_job.py index 428939f7af1a..ca2201180d75 100644 --- a/sdk/ml/azure-ai-ml/tests/pipeline_job/e2etests/test_pipeline_job.py +++ b/sdk/ml/azure-ai-ml/tests/pipeline_job/e2etests/test_pipeline_job.py @@ -7,6 +7,7 @@ from typing import Any, Callable, Dict from devtools_testutils import AzureRecordedTestCase, set_bodiless_matcher +from devtools_testutils import is_live import pydash import pytest from marshmallow import ValidationError @@ -615,6 +616,9 @@ def test_pipeline_job_with_command_job( actual_dict = pydash.omit(pipeline_dict["properties"], *fields_to_omit) assert actual_dict == expected_dict + @pytest.mark.skipif( + condition=not is_live(), + reason="need further investigation for these cases unreliability under none live mode") @pytest.mark.parametrize( "pipeline_job_path", [ diff --git a/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline.pyTestDSLPipelinetest_multi_parallel_components_with_file_input_pipeline_output.json b/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline.pyTestDSLPipelinetest_multi_parallel_components_with_file_input_pipeline_output.json index e94b720c829d..1e0aa48c90e8 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline.pyTestDSLPipelinetest_multi_parallel_components_with_file_input_pipeline_output.json +++ b/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline.pyTestDSLPipelinetest_multi_parallel_components_with_file_input_pipeline_output.json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:21 GMT", + "Date": "Mon, 24 Oct 2022 13:19:53 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-c3a77a5204dfcb7ed424302b32d1489f-2d5d79b101b70746-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-8b4ed3f88e9f9b036676e1f9d2fd64fc-638e4b5743f830d4-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "a1f77b65-22ea-4bed-96df-172821d18ac6", - "x-ms-ratelimit-remaining-subscription-reads": "11939", + "x-ms-correlation-request-id": "d59adcba-7953-4873-b6f5-5dca0c9599c1", + "x-ms-ratelimit-remaining-subscription-reads": "11999", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233221Z:a1f77b65-22ea-4bed-96df-172821d18ac6", - "x-request-time": "0.090" + "x-ms-routing-request-id": "JAPANEAST:20221024T131953Z:d59adcba-7953-4873-b6f5-5dca0c9599c1", + "x-request-time": "0.145" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sas3vrosykmdp4s", - "containerName": "azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-29T22:16:05.5940148\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-29T22:16:06.5431636\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:22 GMT", + "Date": "Mon, 24 Oct 2022 13:19:54 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-dc7cad78e675c9e55014a2dd521cfe3d-3edcafafacdfd012-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-254cf282f457f51625a03885244b744d-d9892e6b9153b6d8-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "cdc8e6d0-3024-4eb3-983e-0beef9c27835", - "x-ms-ratelimit-remaining-subscription-writes": "1159", + "x-ms-correlation-request-id": "bd30b92d-0a48-4c55-894a-2252e7b25a73", + "x-ms-ratelimit-remaining-subscription-writes": "1199", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233222Z:cdc8e6d0-3024-4eb3-983e-0beef9c27835", - "x-request-time": "0.100" + "x-ms-routing-request-id": "JAPANEAST:20221024T131954Z:bd30b92d-0a48-4c55-894a-2252e7b25a73", + "x-request-time": "0.295" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,15 +101,15 @@ } }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 23:32:22 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:19:54 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, @@ -118,9 +118,9 @@ "Content-Length": "969", "Content-MD5": "DhunCanKGufSVuPKEYN51w==", "Content-Type": "application/octet-stream", - "Date": "Thu, 29 Sep 2022 23:32:21 GMT", - "ETag": "\u00220x8DAA272BA182BEE\u0022", - "Last-Modified": "Thu, 29 Sep 2022 23:31:25 GMT", + "Date": "Mon, 24 Oct 2022 13:19:55 GMT", + "ETag": "\u00220x8DA9D77F491F568\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:26:15 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Thu, 29 Sep 2022 23:31:25 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:26:15 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "1992c9ec-9950-4a10-b848-21eccf196b5e", + "x-ms-meta-name": "55c9c168-236e-473f-b35e-c3cba03dad49", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 23:32:22 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:19:55 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Thu, 29 Sep 2022 23:32:21 GMT", + "Date": "Mon, 24 Oct 2022 13:19:55 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:22 GMT", + "Date": "Mon, 24 Oct 2022 13:19:56 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-1d93a5126faed17b74c4d9aef48591c9-3c13cc82fbbea5af-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-fbc6d37d9b3e12952dc8ce1766642601-b5fce1897f2f32a4-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "08c2b745-ad4f-4327-b8eb-8d096f979dd8", - "x-ms-ratelimit-remaining-subscription-writes": "1101", + "x-ms-correlation-request-id": "b35fb63a-c2f3-4fff-8314-09212b5a436d", + "x-ms-ratelimit-remaining-subscription-writes": "1199", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233222Z:08c2b745-ad4f-4327-b8eb-8d096f979dd8", - "x-request-time": "0.180" + "x-ms-routing-request-id": "JAPANEAST:20221024T131956Z:b35fb63a-c2f3-4fff-8314-09212b5a436d", + "x-request-time": "0.139" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,14 +225,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-09-29T23:31:26.2712278\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-09-23T15:26:16.5278828\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-09-29T23:32:22.41062\u002B00:00", - "lastModifiedBy": "Aditi Singhal", + "lastModifiedAt": "2022-10-24T13:19:56.7904526\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "1202", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -280,7 +280,7 @@ }, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -296,26 +296,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2209", + "Content-Length": "2199", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:25 GMT", + "Date": "Mon, 24 Oct 2022 13:19:58 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-2d767ab6cd74e9c1dbe732ea3875cf35-ac3dea0fc4773f64-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-3c5267d1c49cb5d56bab8c23136875e4-0cf71f88123dd320-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "22332d1c-5fb1-4fb8-915b-2dd56756f983", - "x-ms-ratelimit-remaining-subscription-writes": "1100", + "x-ms-correlation-request-id": "4b62fb80-b242-4a2f-a972-e220661fed21", + "x-ms-ratelimit-remaining-subscription-writes": "1198", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233225Z:22332d1c-5fb1-4fb8-915b-2dd56756f983", - "x-request-time": "2.814" + "x-ms-routing-request-id": "JAPANEAST:20221024T131958Z:4b62fb80-b242-4a2f-a972-e220661fed21", + "x-request-time": "0.680" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/a117d1fb-2606-4184-a51f-66f5509ae349", - "name": "a117d1fb-2606-4184-a51f-66f5509ae349", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0b7f72b4-52b8-413f-98fb-67b989a06598", + "name": "0b7f72b4-52b8-413f-98fb-67b989a06598", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -325,7 +325,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "a117d1fb-2606-4184-a51f-66f5509ae349", + "version": "0b7f72b4-52b8-413f-98fb-67b989a06598", "display_name": "BatchScore", "is_deterministic": "True", "type": "parallel", @@ -343,8 +343,8 @@ } }, "task": { - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1", - "environment": "azureml://registries/azureml-dev/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", + "environment": "azureml://registries/azureml/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "entry_script": "score.py", "type": "run_function" @@ -363,11 +363,11 @@ } }, "systemData": { - "createdAt": "2022-09-29T23:31:29.8242337\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-10-24T08:21:17.0116182\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-09-29T23:31:30.3853557\u002B00:00", - "lastModifiedBy": "Aditi Singhal", + "lastModifiedAt": "2022-10-24T08:21:17.1720572\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -379,7 +379,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -387,24 +387,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:25 GMT", + "Date": "Mon, 24 Oct 2022 13:19:58 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-a8dc05dc23f30a3e6bb0fdcb6a519b54-3651bea6ca3d0bc2-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-9a9ce4a488c42c4707168967611943db-627687f239c0150e-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "acb32b0b-0c90-47eb-982a-2236e1ced683", - "x-ms-ratelimit-remaining-subscription-reads": "11938", + "x-ms-correlation-request-id": "90840f18-6c48-41ec-a8bc-8923f777caa6", + "x-ms-ratelimit-remaining-subscription-reads": "11998", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233225Z:acb32b0b-0c90-47eb-982a-2236e1ced683", - "x-request-time": "0.087" + "x-ms-routing-request-id": "JAPANEAST:20221024T131958Z:90840f18-6c48-41ec-a8bc-8923f777caa6", + "x-request-time": "0.147" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -419,17 +419,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sas3vrosykmdp4s", - "containerName": "azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-29T22:16:05.5940148\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-29T22:16:06.5431636\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -443,7 +443,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -451,21 +451,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:25 GMT", + "Date": "Mon, 24 Oct 2022 13:19:59 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-a4e9715249fab3227cca105e53cbefd9-c92eef7b5ed044bb-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-936b9b9b439399cccfff4150d08ce64b-ea3852a4ff261cc6-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "6c60aeb7-61be-485f-8010-54108a404ff1", - "x-ms-ratelimit-remaining-subscription-writes": "1158", + "x-ms-correlation-request-id": "7d351a9a-e174-4246-81db-273d91994906", + "x-ms-ratelimit-remaining-subscription-writes": "1198", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233225Z:6c60aeb7-61be-485f-8010-54108a404ff1", - "x-request-time": "0.102" + "x-ms-routing-request-id": "JAPANEAST:20221024T131959Z:7d351a9a-e174-4246-81db-273d91994906", + "x-request-time": "0.080" }, "ResponseBody": { "secretsType": "AccountKey", @@ -473,15 +473,15 @@ } }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 23:32:25 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:19:59 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, @@ -490,9 +490,9 @@ "Content-Length": "969", "Content-MD5": "DhunCanKGufSVuPKEYN51w==", "Content-Type": "application/octet-stream", - "Date": "Thu, 29 Sep 2022 23:32:24 GMT", - "ETag": "\u00220x8DAA272BA182BEE\u0022", - "Last-Modified": "Thu, 29 Sep 2022 23:31:25 GMT", + "Date": "Mon, 24 Oct 2022 13:19:59 GMT", + "ETag": "\u00220x8DA9D77F491F568\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:26:15 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -501,32 +501,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Thu, 29 Sep 2022 23:31:25 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:26:15 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "1992c9ec-9950-4a10-b848-21eccf196b5e", + "x-ms-meta-name": "55c9c168-236e-473f-b35e-c3cba03dad49", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 23:32:25 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:19:59 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Thu, 29 Sep 2022 23:32:25 GMT", + "Date": "Mon, 24 Oct 2022 13:19:59 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -534,12 +534,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -547,7 +547,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -557,7 +557,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, @@ -565,27 +565,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:26 GMT", + "Date": "Mon, 24 Oct 2022 13:20:00 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-bbaffe11eae208df6a57dae7b74dd7db-e131afdb438c52af-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-c571a8731df0d4925c315c00342abd4e-f2400d30b0232eb5-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "7e225dbd-ce89-4474-aa73-cc3f926411ca", - "x-ms-ratelimit-remaining-subscription-writes": "1099", + "x-ms-correlation-request-id": "7e26caf4-d4f0-44b4-a834-e3ef814b582f", + "x-ms-ratelimit-remaining-subscription-writes": "1197", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233226Z:7e225dbd-ce89-4474-aa73-cc3f926411ca", - "x-request-time": "0.199" + "x-ms-routing-request-id": "JAPANEAST:20221024T132000Z:7e26caf4-d4f0-44b4-a834-e3ef814b582f", + "x-request-time": "0.096" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -597,14 +597,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-09-29T23:31:26.2712278\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-09-23T15:26:16.5278828\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-09-29T23:32:26.2795237\u002B00:00", - "lastModifiedBy": "Aditi Singhal", + "lastModifiedAt": "2022-10-24T13:20:00.5249726\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -618,7 +618,7 @@ "Connection": "keep-alive", "Content-Length": "809", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -628,7 +628,7 @@ "isArchived": false, "componentSpec": { "command": "python convert_data.py --input_data ${{inputs.input_data}} --file_output_data ${{outputs.file_output_data}}", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:5", "name": "azureml_anonymous", "tags": {}, @@ -653,26 +653,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1818", + "Content-Length": "1807", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:30 GMT", + "Date": "Mon, 24 Oct 2022 13:20:02 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-46bb19800d1a25afcc05cc856c596f27-0106d36e838620f3-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-7df2084277be1396c1a438c6eabfb355-a8471ce0c29eaa05-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "af6db138-459f-4a04-bab8-e574aee4d51b", - "x-ms-ratelimit-remaining-subscription-writes": "1098", + "x-ms-correlation-request-id": "b486906b-4b5c-4e68-931c-41a201807d0f", + "x-ms-ratelimit-remaining-subscription-writes": "1196", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233230Z:af6db138-459f-4a04-bab8-e574aee4d51b", - "x-request-time": "3.727" + "x-ms-routing-request-id": "JAPANEAST:20221024T132002Z:b486906b-4b5c-4e68-931c-41a201807d0f", + "x-request-time": "1.033" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/b52df8c8-3cc4-4c59-9181-05a85c2b92fe", - "name": "b52df8c8-3cc4-4c59-9181-05a85c2b92fe", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/4cee2689-473d-4df7-b018-ac2397b5d257", + "name": "4cee2689-473d-4df7-b018-ac2397b5d257", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -682,7 +682,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "b52df8c8-3cc4-4c59-9181-05a85c2b92fe", + "version": "4cee2689-473d-4df7-b018-ac2397b5d257", "display_name": "Convert_To_Mltable_File_Dataset", "is_deterministic": "True", "type": "command", @@ -697,8 +697,8 @@ "type": "mltable" } }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1", - "environment": "azureml://registries/azureml-dev/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/5", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", + "environment": "azureml://registries/azureml/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/5", "resources": { "instance_count": "1" }, @@ -707,11 +707,11 @@ } }, "systemData": { - "createdAt": "2022-09-29T23:32:29.6740155\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-10-24T09:48:39.678435\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-09-29T23:32:29.6740155\u002B00:00", - "lastModifiedBy": "Aditi Singhal", + "lastModifiedAt": "2022-10-24T09:48:39.8575283\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -723,7 +723,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -731,24 +731,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:30 GMT", + "Date": "Mon, 24 Oct 2022 13:20:02 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-789834724bd3ac27e3e6cd0c6605094a-698c6bd9efd14b61-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-0e6be87b543471d27de2da50982f82c6-6cf1eb9bcca5cc6e-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "be787e4d-63b6-478e-b3b7-ed86eafa9dda", - "x-ms-ratelimit-remaining-subscription-reads": "11937", + "x-ms-correlation-request-id": "8a7e1f64-8b78-479d-9a8f-d018dd455357", + "x-ms-ratelimit-remaining-subscription-reads": "11997", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233230Z:be787e4d-63b6-478e-b3b7-ed86eafa9dda", - "x-request-time": "0.142" + "x-ms-routing-request-id": "JAPANEAST:20221024T132002Z:8a7e1f64-8b78-479d-9a8f-d018dd455357", + "x-request-time": "0.115" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -763,17 +763,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sas3vrosykmdp4s", - "containerName": "azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-29T22:16:05.5940148\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-29T22:16:06.5431636\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -787,7 +787,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -795,21 +795,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:30 GMT", + "Date": "Mon, 24 Oct 2022 13:20:03 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-08e653eedb61715b57b400fb5681f251-37607882a841718d-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-b66ca0958cea87db9da37feb2aff400b-65e2e85ca85730ba-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "83da0887-b0c5-40d4-b270-5c718bef42b3", - "x-ms-ratelimit-remaining-subscription-writes": "1157", + "x-ms-correlation-request-id": "bd308c67-7e4a-497e-a0ff-3015a6e04e26", + "x-ms-ratelimit-remaining-subscription-writes": "1197", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233230Z:83da0887-b0c5-40d4-b270-5c718bef42b3", - "x-request-time": "0.112" + "x-ms-routing-request-id": "JAPANEAST:20221024T132003Z:bd308c67-7e4a-497e-a0ff-3015a6e04e26", + "x-request-time": "0.173" }, "ResponseBody": { "secretsType": "AccountKey", @@ -817,15 +817,15 @@ } }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 23:32:30 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:20:03 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, @@ -834,9 +834,9 @@ "Content-Length": "969", "Content-MD5": "DhunCanKGufSVuPKEYN51w==", "Content-Type": "application/octet-stream", - "Date": "Thu, 29 Sep 2022 23:32:29 GMT", - "ETag": "\u00220x8DAA272BA182BEE\u0022", - "Last-Modified": "Thu, 29 Sep 2022 23:31:25 GMT", + "Date": "Mon, 24 Oct 2022 13:20:03 GMT", + "ETag": "\u00220x8DA9D77F491F568\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:26:15 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -845,32 +845,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Thu, 29 Sep 2022 23:31:25 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:26:15 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "1992c9ec-9950-4a10-b848-21eccf196b5e", + "x-ms-meta-name": "55c9c168-236e-473f-b35e-c3cba03dad49", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 23:32:30 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:20:03 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Thu, 29 Sep 2022 23:32:30 GMT", + "Date": "Mon, 24 Oct 2022 13:20:03 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -878,12 +878,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -891,7 +891,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -901,7 +901,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, @@ -909,27 +909,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:31 GMT", + "Date": "Mon, 24 Oct 2022 13:20:04 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-4ca570768792abdee6963eb96a9ac1b1-21c93fc745858e48-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-95f4cc14fd9bb287ce834c36e79a25d4-41f51790f6587c06-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "563ef281-27c4-4f75-8b9d-7b238e46e2c5", - "x-ms-ratelimit-remaining-subscription-writes": "1097", + "x-ms-correlation-request-id": "cbf8e1f6-72b7-4d70-8b85-0feebba7cfc8", + "x-ms-ratelimit-remaining-subscription-writes": "1195", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233231Z:563ef281-27c4-4f75-8b9d-7b238e46e2c5", - "x-request-time": "0.184" + "x-ms-routing-request-id": "JAPANEAST:20221024T132004Z:cbf8e1f6-72b7-4d70-8b85-0feebba7cfc8", + "x-request-time": "0.086" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -941,14 +941,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-09-29T23:31:26.2712278\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-09-23T15:26:16.5278828\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-09-29T23:32:31.2371274\u002B00:00", - "lastModifiedBy": "Aditi Singhal", + "lastModifiedAt": "2022-10-24T13:20:04.4841134\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -962,7 +962,7 @@ "Connection": "keep-alive", "Content-Length": "1202", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -996,7 +996,7 @@ }, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -1012,26 +1012,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2209", + "Content-Length": "2199", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:34 GMT", + "Date": "Mon, 24 Oct 2022 13:20:05 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-5c7880b8b83730eb4f774e4350d55b8a-a94255314d9917de-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-e67b4137e967fcbb0abde59736ac3ab8-43e1da0471e161e6-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "af6c61d8-cbc3-4f07-bb75-222d17f2234b", - "x-ms-ratelimit-remaining-subscription-writes": "1096", + "x-ms-correlation-request-id": "0f5a748f-3455-4750-a0e3-0f094ffe8b0d", + "x-ms-ratelimit-remaining-subscription-writes": "1194", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233234Z:af6c61d8-cbc3-4f07-bb75-222d17f2234b", - "x-request-time": "2.883" + "x-ms-routing-request-id": "JAPANEAST:20221024T132005Z:0f5a748f-3455-4750-a0e3-0f094ffe8b0d", + "x-request-time": "0.464" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/a117d1fb-2606-4184-a51f-66f5509ae349", - "name": "a117d1fb-2606-4184-a51f-66f5509ae349", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0b7f72b4-52b8-413f-98fb-67b989a06598", + "name": "0b7f72b4-52b8-413f-98fb-67b989a06598", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -1041,7 +1041,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "a117d1fb-2606-4184-a51f-66f5509ae349", + "version": "0b7f72b4-52b8-413f-98fb-67b989a06598", "display_name": "BatchScore", "is_deterministic": "True", "type": "parallel", @@ -1059,8 +1059,8 @@ } }, "task": { - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1", - "environment": "azureml://registries/azureml-dev/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", + "environment": "azureml://registries/azureml/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "entry_script": "score.py", "type": "run_function" @@ -1079,11 +1079,11 @@ } }, "systemData": { - "createdAt": "2022-09-29T23:31:29.8242337\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-10-24T08:21:17.0116182\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-09-29T23:31:30.3853557\u002B00:00", - "lastModifiedBy": "Aditi Singhal", + "lastModifiedAt": "2022-10-24T08:21:17.1720572\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -1095,7 +1095,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -1103,24 +1103,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:34 GMT", + "Date": "Mon, 24 Oct 2022 13:20:06 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-cc6ab972a4cecd531003bd30d84fb50d-e6564c183f18444c-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-c3763e8e99fa908ca3857b0a2cb5a755-f49ce7c924e40d34-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "15c669f4-a350-4f6d-a028-5b121add64c2", - "x-ms-ratelimit-remaining-subscription-reads": "11936", + "x-ms-correlation-request-id": "1b9ec9d5-93dd-4c1b-88fc-1d8d5e54e930", + "x-ms-ratelimit-remaining-subscription-reads": "11996", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233234Z:15c669f4-a350-4f6d-a028-5b121add64c2", - "x-request-time": "0.094" + "x-ms-routing-request-id": "JAPANEAST:20221024T132006Z:1b9ec9d5-93dd-4c1b-88fc-1d8d5e54e930", + "x-request-time": "0.072" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -1135,17 +1135,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sas3vrosykmdp4s", - "containerName": "azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-29T22:16:05.5940148\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-29T22:16:06.5431636\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -1159,7 +1159,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -1167,21 +1167,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:34 GMT", + "Date": "Mon, 24 Oct 2022 13:20:06 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-372992e7b5e06634d94c1a32e1383b00-ebcd1152cabda510-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-3dc962122e0d0106f8bcdf580f6dddb9-6b5ac94f4084b64b-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "6f376448-cce9-4387-a45c-de8c2ad2bca8", - "x-ms-ratelimit-remaining-subscription-writes": "1156", + "x-ms-correlation-request-id": "11d457cb-946a-4c8f-9f34-7bfdfe0f3c0a", + "x-ms-ratelimit-remaining-subscription-writes": "1196", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233234Z:6f376448-cce9-4387-a45c-de8c2ad2bca8", - "x-request-time": "0.111" + "x-ms-routing-request-id": "JAPANEAST:20221024T132007Z:11d457cb-946a-4c8f-9f34-7bfdfe0f3c0a", + "x-request-time": "0.087" }, "ResponseBody": { "secretsType": "AccountKey", @@ -1189,15 +1189,15 @@ } }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/mnist-data/0.png", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/mnist-data/0.png", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 23:32:34 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:20:07 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, @@ -1206,9 +1206,9 @@ "Content-Length": "223", "Content-MD5": "yLW2CQQeldeN1S7hH1/5Nw==", "Content-Type": "application/octet-stream", - "Date": "Thu, 29 Sep 2022 23:32:34 GMT", - "ETag": "\u00220x8DAA272BD4B9081\u0022", - "Last-Modified": "Thu, 29 Sep 2022 23:31:31 GMT", + "Date": "Mon, 24 Oct 2022 13:20:07 GMT", + "ETag": "\u00220x8DA9D77C1560DE2\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:24:49 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -1217,32 +1217,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Thu, 29 Sep 2022 23:31:31 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:24:48 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "776195be-0520-410c-baf6-30d470c2ba98", + "x-ms-meta-name": "e6954628-b564-4b7e-bf0e-472284fbfa3f", "x-ms-meta-upload_status": "completed", - "x-ms-meta-version": "9e2621cd-06f1-4034-af15-7e796b2f5bb7", + "x-ms-meta-version": "c9aa34c9-8122-4239-abd0-25287b724051", "x-ms-server-encrypted": "true", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/az-ml-artifacts/00000000000000000000000000000000/mnist-data/0.png", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/mnist-data/0.png", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 23:32:34 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:20:07 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Thu, 29 Sep 2022 23:32:34 GMT", + "Date": "Mon, 24 Oct 2022 13:20:07 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -1250,20 +1250,20 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-06-01-preview", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "3905", + "Content-Length": "3953", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -1293,7 +1293,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -1312,10 +1312,11 @@ "outputs": {}, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/a117d1fb-2606-4184-a51f-66f5509ae349", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0b7f72b4-52b8-413f-98fb-67b989a06598", "retry_settings": null, "logging_level": null, - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null }, "convert_data_node": { "resources": null, @@ -1340,7 +1341,7 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/b52df8c8-3cc4-4c59-9181-05a85c2b92fe" + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/4cee2689-473d-4df7-b018-ac2397b5d257" }, "batch_inference_node2": { "type": "parallel", @@ -1354,7 +1355,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -1379,10 +1380,11 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/a117d1fb-2606-4184-a51f-66f5509ae349", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0b7f72b4-52b8-413f-98fb-67b989a06598", "retry_settings": null, "logging_level": null, - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null } }, "outputs": { @@ -1400,22 +1402,22 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "6794", + "Content-Length": "6897", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:39 GMT", + "Date": "Mon, 24 Oct 2022 13:20:16 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-06-01-preview", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-8548930f3dfc7a103bb59b986453e4c6-4dc230f072e6d86f-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-c289f71ca5f5eafca651682ba7073cf1-6d8b3f0fa61ffe48-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "ee855ce3-289c-49a5-abc8-2bffc74b8acc", - "x-ms-ratelimit-remaining-subscription-writes": "1095", + "x-ms-correlation-request-id": "c1ff423f-777b-4ed5-ac55-55c07500fc7b", + "x-ms-ratelimit-remaining-subscription-writes": "1193", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233239Z:ee855ce3-289c-49a5-abc8-2bffc74b8acc", - "x-request-time": "3.082" + "x-ms-routing-request-id": "JAPANEAST:20221024T132016Z:c1ff423f-777b-4ed5-ac55-55c07500fc7b", + "x-request-time": "4.356" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000", @@ -1443,10 +1445,11 @@ "Tracking": { "jobServiceType": "Tracking", "port": null, - "endpoint": "azureml://master.api.azureml-test.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", + "endpoint": "azureml://eastus2.api.azureml.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", "status": null, "errorMessage": null, - "properties": null + "properties": null, + "nodes": null }, "Studio": { "jobServiceType": "Studio", @@ -1454,7 +1457,8 @@ "endpoint": "https://ml.azure.com/runs/000000000000000000000?wsid=/subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000", "status": null, "errorMessage": null, - "properties": null + "properties": null, + "nodes": null } }, "computeId": null, @@ -1479,7 +1483,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -1498,10 +1502,11 @@ "outputs": {}, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/a117d1fb-2606-4184-a51f-66f5509ae349", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0b7f72b4-52b8-413f-98fb-67b989a06598", "retry_settings": null, "logging_level": null, - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null }, "convert_data_node": { "resources": null, @@ -1526,7 +1531,7 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/b52df8c8-3cc4-4c59-9181-05a85c2b92fe" + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/4cee2689-473d-4df7-b018-ac2397b5d257" }, "batch_inference_node2": { "type": "parallel", @@ -1540,7 +1545,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -1565,10 +1570,11 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/a117d1fb-2606-4184-a51f-66f5509ae349", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0b7f72b4-52b8-413f-98fb-67b989a06598", "retry_settings": null, "logging_level": null, - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null } }, "inputs": { @@ -1590,21 +1596,21 @@ "sourceJobId": null }, "systemData": { - "createdAt": "2022-09-29T23:32:39.1319169\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-10-24T13:20:16.1716162\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000/cancel?api-version=2022-06-01-preview", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000/cancel?api-version=2022-10-01-preview", "RequestMethod": "POST", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 202, @@ -1612,81 +1618,50 @@ "Cache-Control": "no-cache", "Content-Length": "4", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:41 GMT", + "Date": "Mon, 24 Oct 2022 13:20:19 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:86253a4f-a7a6-4008-8c86-ce9cf2978bc1:000000000000000000000?api-version=2022-06-01-preview", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/eastus2/mfeOperationResults/jc:e950f876-7257-4cf3-99a5-ff66812ac44c:000000000000000000000?api-version=2022-10-01-preview", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", "x-ms-async-operation-timeout": "PT1H", - "x-ms-correlation-request-id": "b8ad1295-56eb-4776-a26c-faad7b591473", - "x-ms-ratelimit-remaining-subscription-writes": "1155", + "x-ms-correlation-request-id": "5e8eadfd-8e5a-4746-8b1a-4e0d3e56080a", + "x-ms-ratelimit-remaining-subscription-writes": "1195", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233241Z:b8ad1295-56eb-4776-a26c-faad7b591473", - "x-request-time": "0.744" + "x-ms-routing-request-id": "JAPANEAST:20221024T132020Z:5e8eadfd-8e5a-4746-8b1a-4e0d3e56080a", + "x-request-time": "0.702" }, "ResponseBody": "null" }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:86253a4f-a7a6-4008-8c86-ce9cf2978bc1:000000000000000000000?api-version=2022-06-01-preview", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/eastus2/mfeOperationResults/jc:e950f876-7257-4cf3-99a5-ff66812ac44c:000000000000000000000?api-version=2022-10-01-preview", "RequestMethod": "GET", "RequestHeaders": { "Accept": "*/*", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" - }, - "RequestBody": null, - "StatusCode": 202, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Content-Length": "2", - "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:41 GMT", - "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:86253a4f-a7a6-4008-8c86-ce9cf2978bc1:000000000000000000000?api-version=2022-06-01-preview", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-01", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "f4410131-ffc4-4474-8855-9a5640b026fb", - "x-ms-ratelimit-remaining-subscription-reads": "11935", - "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233241Z:f4410131-ffc4-4474-8855-9a5640b026fb", - "x-request-time": "0.033" - }, - "ResponseBody": {} - }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:86253a4f-a7a6-4008-8c86-ce9cf2978bc1:000000000000000000000?api-version=2022-06-01-preview", - "RequestMethod": "GET", - "RequestHeaders": { - "Accept": "*/*", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", "Content-Length": "0", - "Date": "Thu, 29 Sep 2022 23:33:11 GMT", + "Date": "Mon, 24 Oct 2022 13:20:20 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-6e3d958615dfbff7b8a342678baa8e09-eaa024613ed12eb6-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-68e66c73aa6ef87ef6b3dc04360a974d-204055e881edd86d-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "b96866e3-a3b8-4462-ad94-3b90695c6e68", - "x-ms-ratelimit-remaining-subscription-reads": "11934", + "x-ms-correlation-request-id": "979aaa64-1761-424b-87bb-652566eac1cd", + "x-ms-ratelimit-remaining-subscription-reads": "11995", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233311Z:b96866e3-a3b8-4462-ad94-3b90695c6e68", - "x-request-time": "0.061" + "x-ms-routing-request-id": "JAPANEAST:20221024T132020Z:979aaa64-1761-424b-87bb-652566eac1cd", + "x-request-time": "0.111" }, "ResponseBody": null } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline.pyTestDSLPipelinetest_parallel_components_with_file_input.json b/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline.pyTestDSLPipelinetest_parallel_components_with_file_input.json index 443899687231..6a47edee47b4 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline.pyTestDSLPipelinetest_parallel_components_with_file_input.json +++ b/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline.pyTestDSLPipelinetest_parallel_components_with_file_input.json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:25:08 GMT", + "Date": "Mon, 24 Oct 2022 13:17:42 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-f9b41025f7e0727ff5ae689fcc30eda3-f78cf1c0bff5a5fd-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-08d6a43629bcff598e825befe2d3c572-8f86eed3db979d81-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "45177ea1-986d-46a9-b60b-ad7eefa89b08", - "x-ms-ratelimit-remaining-subscription-reads": "11996", + "x-ms-correlation-request-id": "264e7fca-41fc-4a48-abfa-3e76aed19e13", + "x-ms-ratelimit-remaining-subscription-reads": "11999", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T122508Z:45177ea1-986d-46a9-b60b-ad7eefa89b08", - "x-request-time": "0.106" + "x-ms-routing-request-id": "JAPANEAST:20221024T131742Z:264e7fca-41fc-4a48-abfa-3e76aed19e13", + "x-request-time": "0.543" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:25:08 GMT", + "Date": "Mon, 24 Oct 2022 13:17:42 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-26034794f6067bcc541eb9e6f826172e-1e80b73ac4b2e769-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-81a156c4fad317bb101ed09f732d1bb7-f042265a7cbf2f1e-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "d40d528c-76d8-4957-9c09-024c7036dfa3", + "x-ms-correlation-request-id": "d12578c5-e966-4dbb-9436-fe6bac105e96", "x-ms-ratelimit-remaining-subscription-writes": "1199", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T122509Z:d40d528c-76d8-4957-9c09-024c7036dfa3", - "x-request-time": "0.095" + "x-ms-routing-request-id": "JAPANEAST:20221024T131743Z:d12578c5-e966-4dbb-9436-fe6bac105e96", + "x-request-time": "0.163" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,14 +101,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:25:09 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:17:43 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -118,9 +118,9 @@ "Content-Length": "969", "Content-MD5": "DhunCanKGufSVuPKEYN51w==", "Content-Type": "application/octet-stream", - "Date": "Wed, 12 Oct 2022 12:25:09 GMT", - "ETag": "\u00220x8DA9D4A193DC816\u0022", - "Last-Modified": "Fri, 23 Sep 2022 09:58:00 GMT", + "Date": "Mon, 24 Oct 2022 13:17:44 GMT", + "ETag": "\u00220x8DA9D77F491F568\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:26:15 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,10 +129,10 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Fri, 23 Sep 2022 09:57:59 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:26:15 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "3af49689-e732-4d3f-9854-43df40223df3", + "x-ms-meta-name": "55c9c168-236e-473f-b35e-c3cba03dad49", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", @@ -141,20 +141,20 @@ "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:25:10 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:17:44 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Wed, 12 Oct 2022 12:25:09 GMT", + "Date": "Mon, 24 Oct 2022 13:17:44 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -167,7 +167,7 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:25:11 GMT", + "Date": "Mon, 24 Oct 2022 13:17:45 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-b784c86fdb2bfc69e59c470b3e778b76-6ce008afbda9b973-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-a880db34eecf58eb7a5cf31426ec3609-c2d2b0667d8ae89a-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "79881ea0-824a-4c4a-92d6-69e4a63eba5d", + "x-ms-correlation-request-id": "d8df432c-6c5b-40b8-a7e7-178bc44dd37b", "x-ms-ratelimit-remaining-subscription-writes": "1199", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T122511Z:79881ea0-824a-4c4a-92d6-69e4a63eba5d", - "x-request-time": "0.206" + "x-ms-routing-request-id": "JAPANEAST:20221024T131746Z:d8df432c-6c5b-40b8-a7e7-178bc44dd37b", + "x-request-time": "0.498" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,14 +225,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-09-23T09:58:01.1651738\u002B00:00", - "createdBy": "Ying Chen", + "createdAt": "2022-09-23T15:26:16.5278828\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-10-12T12:25:11.502554\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-24T13:17:46.1651702\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "1202", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -280,7 +280,7 @@ }, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -296,26 +296,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2209", + "Content-Length": "2199", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:25:13 GMT", + "Date": "Mon, 24 Oct 2022 13:17:47 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-d5e1ddc4a3558a3df7323e359dc0318f-0a5f53f848d9c745-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-fbd2dfa1b777acce33c604d9b3075df5-0fda83eeb536d05e-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "fb29475c-9225-4553-a102-306307fd892c", + "x-ms-correlation-request-id": "07ca0f85-baf5-43ab-bdca-30cdec4a9d1c", "x-ms-ratelimit-remaining-subscription-writes": "1198", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T122513Z:fb29475c-9225-4553-a102-306307fd892c", - "x-request-time": "1.686" + "x-ms-routing-request-id": "JAPANEAST:20221024T131747Z:07ca0f85-baf5-43ab-bdca-30cdec4a9d1c", + "x-request-time": "0.814" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/b6a05c03-ad84-46ce-b326-ecc8c5d44726", - "name": "b6a05c03-ad84-46ce-b326-ecc8c5d44726", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0b7f72b4-52b8-413f-98fb-67b989a06598", + "name": "0b7f72b4-52b8-413f-98fb-67b989a06598", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -325,7 +325,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "b6a05c03-ad84-46ce-b326-ecc8c5d44726", + "version": "0b7f72b4-52b8-413f-98fb-67b989a06598", "display_name": "BatchScore", "is_deterministic": "True", "type": "parallel", @@ -343,8 +343,8 @@ } }, "task": { - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", - "environment": "azureml://registries/azureml-dev/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", + "environment": "azureml://registries/azureml/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "entry_script": "score.py", "type": "run_function" @@ -363,11 +363,11 @@ } }, "systemData": { - "createdAt": "2022-10-12T11:41:10.7336842\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-10-24T08:21:17.0116182\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-10-12T11:41:11.2470066\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-24T08:21:17.1720572\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -379,7 +379,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -387,24 +387,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:25:13 GMT", + "Date": "Mon, 24 Oct 2022 13:17:47 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-92dafa6ea1a817b5e7a855f19a8f98b3-17060e551f2c7299-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-6a89c35e31ecb11e644c9fa919174ffe-18eb84c31e740495-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "d4bcf69c-8dd8-4a2d-ba83-5380fcb334ec", - "x-ms-ratelimit-remaining-subscription-reads": "11995", + "x-ms-correlation-request-id": "683c4664-aa5f-4eb1-a77a-5306711d9ce8", + "x-ms-ratelimit-remaining-subscription-reads": "11998", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T122514Z:d4bcf69c-8dd8-4a2d-ba83-5380fcb334ec", - "x-request-time": "0.081" + "x-ms-routing-request-id": "JAPANEAST:20221024T131748Z:683c4664-aa5f-4eb1-a77a-5306711d9ce8", + "x-request-time": "0.071" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -419,17 +419,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -443,7 +443,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -451,21 +451,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:25:14 GMT", + "Date": "Mon, 24 Oct 2022 13:17:48 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-c4d37a309bb47c8e96108eada121a38b-9e7cd15ab39c8211-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-3a70004ab8f3bccafb6ca7ca1b5e61c9-75f5063aea31deba-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "7a78304f-8b4a-4d3a-be5f-93195b20fa25", + "x-ms-correlation-request-id": "39a95459-f81b-46a8-8250-b973c2bc637b", "x-ms-ratelimit-remaining-subscription-writes": "1198", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T122514Z:7a78304f-8b4a-4d3a-be5f-93195b20fa25", - "x-request-time": "0.105" + "x-ms-routing-request-id": "JAPANEAST:20221024T131748Z:39a95459-f81b-46a8-8250-b973c2bc637b", + "x-request-time": "0.184" }, "ResponseBody": { "secretsType": "AccountKey", @@ -473,14 +473,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/mnist-data/0.png", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/mnist-data/0.png", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:25:14 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:17:48 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -490,9 +490,9 @@ "Content-Length": "223", "Content-MD5": "yLW2CQQeldeN1S7hH1/5Nw==", "Content-Type": "application/octet-stream", - "Date": "Wed, 12 Oct 2022 12:25:13 GMT", - "ETag": "\u00220x8DA9D49DDA8E2B9\u0022", - "Last-Modified": "Fri, 23 Sep 2022 09:56:20 GMT", + "Date": "Mon, 24 Oct 2022 13:17:48 GMT", + "ETag": "\u00220x8DA9D77C1560DE2\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:24:49 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -501,32 +501,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Fri, 23 Sep 2022 09:56:19 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:24:48 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "6d38069b-69f7-4247-bed0-fffe996f3098", + "x-ms-meta-name": "e6954628-b564-4b7e-bf0e-472284fbfa3f", "x-ms-meta-upload_status": "completed", - "x-ms-meta-version": "315ab246-e719-41ed-9ad8-28f2f315a8e2", + "x-ms-meta-version": "c9aa34c9-8122-4239-abd0-25287b724051", "x-ms-server-encrypted": "true", "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/mnist-data/0.png", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/mnist-data/0.png", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:25:15 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:17:49 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Wed, 12 Oct 2022 12:25:14 GMT", + "Date": "Mon, 24 Oct 2022 13:17:49 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -545,9 +545,9 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "1810", + "Content-Length": "1834", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -577,7 +577,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -596,10 +596,11 @@ "outputs": {}, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/b6a05c03-ad84-46ce-b326-ecc8c5d44726", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0b7f72b4-52b8-413f-98fb-67b989a06598", "retry_settings": null, "logging_level": null, - "mini_batch_size": 5 + "mini_batch_size": 5, + "partition_keys": null } }, "outputs": {}, @@ -612,22 +613,22 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "4045", + "Content-Length": "4070", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:25:21 GMT", + "Date": "Mon, 24 Oct 2022 13:17:57 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-574f83d0313e831319b4e2988fe4ae5e-ff28f84898611a58-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-75d3709e9deeedfe6c3474aefa8e8753-d1b8c5ba6d9a23dd-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "3c56c481-8391-4a48-bff0-08eb254be009", + "x-ms-correlation-request-id": "6aa2b137-2b2f-4527-a18e-a963c9aa5429", "x-ms-ratelimit-remaining-subscription-writes": "1197", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T122522Z:3c56c481-8391-4a48-bff0-08eb254be009", - "x-request-time": "2.964" + "x-ms-routing-request-id": "JAPANEAST:20221024T131757Z:6aa2b137-2b2f-4527-a18e-a963c9aa5429", + "x-request-time": "4.308" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000", @@ -655,7 +656,7 @@ "Tracking": { "jobServiceType": "Tracking", "port": null, - "endpoint": "azureml://master.api.azureml-test.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", + "endpoint": "azureml://eastus2.api.azureml.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", "status": null, "errorMessage": null, "properties": null, @@ -693,7 +694,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -712,10 +713,11 @@ "outputs": {}, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/b6a05c03-ad84-46ce-b326-ecc8c5d44726", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0b7f72b4-52b8-413f-98fb-67b989a06598", "retry_settings": null, "logging_level": null, - "mini_batch_size": 5 + "mini_batch_size": 5, + "partition_keys": null } }, "inputs": { @@ -730,8 +732,8 @@ "sourceJobId": null }, "systemData": { - "createdAt": "2022-10-12T12:25:21.2832295\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-10-24T13:17:57.4380442\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User" } } @@ -744,7 +746,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 202, @@ -752,81 +754,50 @@ "Cache-Control": "no-cache", "Content-Length": "4", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:25:24 GMT", + "Date": "Mon, 24 Oct 2022 13:18:00 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/eastus2/mfeOperationResults/jc:e950f876-7257-4cf3-99a5-ff66812ac44c:000000000000000000000?api-version=2022-10-01-preview", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", "x-ms-async-operation-timeout": "PT1H", - "x-ms-correlation-request-id": "cc012320-6286-41bf-b6b9-10f8fdd844c3", + "x-ms-correlation-request-id": "d8e8b01b-f1af-4d2a-b5b7-cd48b3cfef4a", "x-ms-ratelimit-remaining-subscription-writes": "1197", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T122524Z:cc012320-6286-41bf-b6b9-10f8fdd844c3", - "x-request-time": "0.785" + "x-ms-routing-request-id": "JAPANEAST:20221024T131800Z:d8e8b01b-f1af-4d2a-b5b7-cd48b3cfef4a", + "x-request-time": "0.738" }, "ResponseBody": "null" }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/eastus2/mfeOperationResults/jc:e950f876-7257-4cf3-99a5-ff66812ac44c:000000000000000000000?api-version=2022-10-01-preview", "RequestMethod": "GET", "RequestHeaders": { "Accept": "*/*", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" - }, - "RequestBody": null, - "StatusCode": 202, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Content-Length": "2", - "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:25:24 GMT", - "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-01", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "d37946e8-b291-4229-b2f0-e2339cea3347", - "x-ms-ratelimit-remaining-subscription-reads": "11994", - "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T122525Z:d37946e8-b291-4229-b2f0-e2339cea3347", - "x-request-time": "0.073" - }, - "ResponseBody": {} - }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:e61cd5e2-512f-475e-9842-5e2a973993b8:000000000000000000000?api-version=2022-10-01-preview", - "RequestMethod": "GET", - "RequestHeaders": { - "Accept": "*/*", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", "Content-Length": "0", - "Date": "Wed, 12 Oct 2022 12:25:54 GMT", + "Date": "Mon, 24 Oct 2022 13:18:01 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-583c4df91be0895b5dd2c204a41e9621-e7f6483800ccc7fa-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-49f41c240ccd23fa7fdb082eaddbd026-06ac4f741833b5b2-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "b3f0623a-fbe0-4680-b083-9802daeb419c", - "x-ms-ratelimit-remaining-subscription-reads": "11993", + "x-ms-correlation-request-id": "ad17e5de-bede-439b-8dbc-1f5b86c8cf2b", + "x-ms-ratelimit-remaining-subscription-reads": "11997", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T122555Z:b3f0623a-fbe0-4680-b083-9802daeb419c", - "x-request-time": "0.060" + "x-ms-routing-request-id": "JAPANEAST:20221024T131801Z:ad17e5de-bede-439b-8dbc-1f5b86c8cf2b", + "x-request-time": "0.024" }, "ResponseBody": null } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline.pyTestDSLPipelinetest_parallel_components_with_tabular_input.json b/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline.pyTestDSLPipelinetest_parallel_components_with_tabular_input.json index 826847a09399..5053b598a7b1 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline.pyTestDSLPipelinetest_parallel_components_with_tabular_input.json +++ b/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline.pyTestDSLPipelinetest_parallel_components_with_tabular_input.json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 15:45:35 GMT", + "Date": "Mon, 24 Oct 2022 13:13:05 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-0f7b6e2762057f074868d4bd38686e0c-e0cc780a554d2777-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-842d78edfb6c956f4f6d632523d743ab-efe33d3ce52243ba-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "3494e1ab-b033-4964-954c-6deeab02a209", - "x-ms-ratelimit-remaining-subscription-reads": "11945", + "x-ms-correlation-request-id": "5411e79c-0abe-4a87-87d9-dc3e371c5475", + "x-ms-ratelimit-remaining-subscription-reads": "11999", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220930T154536Z:3494e1ab-b033-4964-954c-6deeab02a209", - "x-request-time": "0.124" + "x-ms-routing-request-id": "JAPANEAST:20221024T131305Z:5411e79c-0abe-4a87-87d9-dc3e371c5475", + "x-request-time": "0.159" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sas3vrosykmdp4s", - "containerName": "azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-29T22:16:05.5940148\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-29T22:16:06.5431636\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 15:45:36 GMT", + "Date": "Mon, 24 Oct 2022 13:13:05 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-5840388df505f243583fd5902003a726-767cfd47c26dc6f1-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-63289d09854bf68fc2f764b673a29314-53c3a12c7d8fa693-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "498ec15d-f485-49a1-854a-24492ca5820a", - "x-ms-ratelimit-remaining-subscription-writes": "1166", + "x-ms-correlation-request-id": "4ed6d3f4-0181-4ad2-bc3b-04a512d0ea4b", + "x-ms-ratelimit-remaining-subscription-writes": "1199", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220930T154536Z:498ec15d-f485-49a1-854a-24492ca5820a", - "x-request-time": "0.095" + "x-ms-routing-request-id": "JAPANEAST:20221024T131305Z:4ed6d3f4-0181-4ad2-bc3b-04a512d0ea4b", + "x-request-time": "0.187" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,15 +101,15 @@ } }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/src/tabular_run_with_model.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/tabular_run_with_model.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Fri, 30 Sep 2022 15:45:37 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:13:05 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, @@ -118,9 +118,9 @@ "Content-Length": "1102", "Content-MD5": "jO1FYErTQcHautv7oG0/KQ==", "Content-Type": "application/octet-stream", - "Date": "Fri, 30 Sep 2022 15:45:36 GMT", - "ETag": "\u00220x8DAA27297C3C99F\u0022", - "Last-Modified": "Thu, 29 Sep 2022 23:30:28 GMT", + "Date": "Mon, 24 Oct 2022 13:13:06 GMT", + "ETag": "\u00220x8DA9D805F140855\u0022", + "Last-Modified": "Fri, 23 Sep 2022 16:26:30 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Thu, 29 Sep 2022 23:30:28 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 16:26:29 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "c577b594-3497-4cd5-b811-dfe339626a6d", + "x-ms-meta-name": "47ddf675-0155-4289-96eb-c37908b696c0", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/az-ml-artifacts/00000000000000000000000000000000/src/tabular_run_with_model.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/tabular_run_with_model.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Fri, 30 Sep 2022 15:45:37 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:13:07 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Fri, 30 Sep 2022 15:45:36 GMT", + "Date": "Mon, 24 Oct 2022 13:13:07 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/c577b594-3497-4cd5-b811-dfe339626a6d/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/47ddf675-0155-4289-96eb-c37908b696c0/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 15:45:36 GMT", + "Date": "Mon, 24 Oct 2022 13:13:08 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-1b8e4b80078f4172716b300e9f967f8b-2378cdf00e1d9322-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-a43937ebe2e546406f8d6211d70d67ca-9f8bed1b027c2056-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "8e6c2a26-7571-411f-a103-971dd97e07f3", - "x-ms-ratelimit-remaining-subscription-writes": "1107", + "x-ms-correlation-request-id": "1f22e4bf-7383-4da0-bf95-a14fe52afdc5", + "x-ms-ratelimit-remaining-subscription-writes": "1199", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220930T154537Z:8e6c2a26-7571-411f-a103-971dd97e07f3", - "x-request-time": "0.260" + "x-ms-routing-request-id": "JAPANEAST:20221024T131308Z:1f22e4bf-7383-4da0-bf95-a14fe52afdc5", + "x-request-time": "0.188" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/c577b594-3497-4cd5-b811-dfe339626a6d/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/47ddf675-0155-4289-96eb-c37908b696c0/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,14 +225,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-09-29T23:30:28.7673439\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-09-23T16:26:31.1781796\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-09-30T15:45:37.6275285\u002B00:00", - "lastModifiedBy": "Aditi Singhal", + "lastModifiedAt": "2022-10-24T13:13:08.5395181\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "416", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -258,24 +258,24 @@ }, "StatusCode": 201, "ResponseHeaders": { - "Build-ID": "ca6", + "Build-ID": "chg", "Cache-Control": "no-cache", "Content-Length": "1359", "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 15:45:51 GMT", + "Date": "Mon, 24 Oct 2022 13:13:09 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-3609e754d8ac5b28dc70d81326c68f3c-2896538c5b85d600-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-554912e9af06607c635ae61510dd9631-db52ef5399b31cb8-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "80db4467-949b-4a1a-a16e-05699f81e924", - "x-ms-ratelimit-remaining-subscription-writes": "1106", + "x-ms-correlation-request-id": "8a6c700d-eb36-4a89-b749-cb0010a01e36", + "x-ms-ratelimit-remaining-subscription-writes": "1198", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220930T154551Z:80db4467-949b-4a1a-a16e-05699f81e924", - "x-request-time": "13.300" + "x-ms-routing-request-id": "JAPANEAST:20221024T131309Z:8a6c700d-eb36-4a89-b749-cb0010a01e36", + "x-request-time": "0.739" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af", @@ -293,11 +293,11 @@ "osType": "Linux" }, "systemData": { - "createdAt": "2022-09-29T23:30:29.9190948\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-09-23T15:25:10.3353821\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-09-29T23:30:29.9190948\u002B00:00", - "lastModifiedBy": "Aditi Singhal", + "lastModifiedAt": "2022-09-23T15:25:10.3353821\u002B00:00", + "lastModifiedBy": "Zhengfei Wang", "lastModifiedByType": "User" } } @@ -311,7 +311,7 @@ "Connection": "keep-alive", "Content-Length": "1542", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -347,7 +347,7 @@ "logging_level": "DEBUG", "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/c577b594-3497-4cd5-b811-dfe339626a6d/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/47ddf675-0155-4289-96eb-c37908b696c0/versions/1", "entry_script": "tabular_run_with_model.py", "program_arguments": "--model ${{inputs.score_model}}", "append_row_to": "${{outputs.job_out_path}}", @@ -368,26 +368,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2537", + "Content-Length": "2536", "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 15:45:52 GMT", + "Date": "Mon, 24 Oct 2022 13:13:10 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-ebd46a36fafa94fb7d73829b40d68642-0a01b6dc167cd17e-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-299ea71f140a4e77be57f3d84ddac28b-8db4b1d3cf125110-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "95c995a9-8a3b-49b6-bc13-e027041d08cd", - "x-ms-ratelimit-remaining-subscription-writes": "1105", + "x-ms-correlation-request-id": "807cca45-332b-417a-b72f-62aa8ed788be", + "x-ms-ratelimit-remaining-subscription-writes": "1197", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220930T154552Z:95c995a9-8a3b-49b6-bc13-e027041d08cd", - "x-request-time": "0.645" + "x-ms-routing-request-id": "JAPANEAST:20221024T131310Z:807cca45-332b-417a-b72f-62aa8ed788be", + "x-request-time": "0.470" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/afd38eb3-b2c4-49db-b1ad-2dc05e6031c2", - "name": "afd38eb3-b2c4-49db-b1ad-2dc05e6031c2", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/234be6de-944e-4498-bdf4-e89058b5f16c", + "name": "234be6de-944e-4498-bdf4-e89058b5f16c", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -397,7 +397,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "afd38eb3-b2c4-49db-b1ad-2dc05e6031c2", + "version": "234be6de-944e-4498-bdf4-e89058b5f16c", "display_name": "BatchScore", "is_deterministic": "True", "type": "parallel", @@ -420,7 +420,7 @@ } }, "task": { - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/c577b594-3497-4cd5-b811-dfe339626a6d/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/47ddf675-0155-4289-96eb-c37908b696c0/versions/1", "environment": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af", "program_arguments": "--model ${{inputs.score_model}}", "entry_script": "tabular_run_with_model.py", @@ -441,11 +441,11 @@ } }, "systemData": { - "createdAt": "2022-09-29T23:30:44.3197662\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-09-23T16:26:48.5666167\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-09-29T23:30:44.9302457\u002B00:00", - "lastModifiedBy": "Aditi Singhal", + "lastModifiedAt": "2022-09-23T16:26:48.762222\u002B00:00", + "lastModifiedBy": "Zhengfei Wang", "lastModifiedByType": "User" } } @@ -457,7 +457,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -465,24 +465,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 15:45:52 GMT", + "Date": "Mon, 24 Oct 2022 13:13:11 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-4552959b3e72bb19fda5176e5f612d0c-e0291632001b6908-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-22a9c7d0fc1173d07cd942d5d8951f56-b4daad7cd0520df4-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "0160914d-578f-4ab6-8d14-921e099f1482", - "x-ms-ratelimit-remaining-subscription-reads": "11944", + "x-ms-correlation-request-id": "fae7f6e5-8d66-4b44-94a2-9fac09355fc5", + "x-ms-ratelimit-remaining-subscription-reads": "11998", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220930T154552Z:0160914d-578f-4ab6-8d14-921e099f1482", - "x-request-time": "0.122" + "x-ms-routing-request-id": "JAPANEAST:20221024T131311Z:fae7f6e5-8d66-4b44-94a2-9fac09355fc5", + "x-request-time": "0.172" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -497,17 +497,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sas3vrosykmdp4s", - "containerName": "azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-29T22:16:05.5940148\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-29T22:16:06.5431636\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -521,7 +521,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -529,21 +529,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 15:45:52 GMT", + "Date": "Mon, 24 Oct 2022 13:13:12 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-70c29e1a5b837b4a7b6abfbf440574f2-566b53823cb7e67b-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-437c7b37870558263abbf2d1e204b0b2-08b29e091c83daaf-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "c2be8162-72b3-48cd-9a3b-7a3c40530276", - "x-ms-ratelimit-remaining-subscription-writes": "1165", + "x-ms-correlation-request-id": "53e54994-c64e-4112-a03f-49f0658c7f73", + "x-ms-ratelimit-remaining-subscription-writes": "1198", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220930T154552Z:c2be8162-72b3-48cd-9a3b-7a3c40530276", - "x-request-time": "0.106" + "x-ms-routing-request-id": "JAPANEAST:20221024T131312Z:53e54994-c64e-4112-a03f-49f0658c7f73", + "x-request-time": "0.131" }, "ResponseBody": { "secretsType": "AccountKey", @@ -551,15 +551,15 @@ } }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/neural-iris-mltable/MLTable", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/neural-iris-mltable/MLTable", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Fri, 30 Sep 2022 15:45:52 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:13:12 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, @@ -568,9 +568,9 @@ "Content-Length": "152", "Content-MD5": "LPwZTVvE9cmq2xCV9B8RmQ==", "Content-Type": "application/octet-stream", - "Date": "Fri, 30 Sep 2022 15:45:52 GMT", - "ETag": "\u00220x8DAA272A250E73B\u0022", - "Last-Modified": "Thu, 29 Sep 2022 23:30:45 GMT", + "Date": "Mon, 24 Oct 2022 13:13:12 GMT", + "ETag": "\u00220x8DA9D77E4BE9973\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:25:49 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -579,32 +579,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Thu, 29 Sep 2022 23:30:45 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:25:48 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "a3dcc536-e9a4-4124-a19e-8b424a5d2832", + "x-ms-meta-name": "75be94a1-b11f-438f-9809-e66170c6a572", "x-ms-meta-upload_status": "completed", - "x-ms-meta-version": "5531f48b-72ce-4c65-bdf6-678070a65a18", + "x-ms-meta-version": "b56612a1-59bf-45b4-bfb9-4924980b2134", "x-ms-server-encrypted": "true", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/az-ml-artifacts/00000000000000000000000000000000/neural-iris-mltable/MLTable", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/neural-iris-mltable/MLTable", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Fri, 30 Sep 2022 15:45:53 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:13:12 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Fri, 30 Sep 2022 15:45:52 GMT", + "Date": "Mon, 24 Oct 2022 13:13:12 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -612,7 +612,7 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, @@ -623,7 +623,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -631,24 +631,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 15:45:53 GMT", + "Date": "Mon, 24 Oct 2022 13:13:13 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-9218d3a4e019e2430700b266a3c82e2e-3a502d77514a81d1-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-2bd3b10a0d039c67ce90e77f17abb120-6bd683cbcca969c5-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "407d323c-b07f-409d-83d8-33a598250dbf", - "x-ms-ratelimit-remaining-subscription-reads": "11943", + "x-ms-correlation-request-id": "9ebb3519-2e17-498f-abb7-763a516a7e38", + "x-ms-ratelimit-remaining-subscription-reads": "11997", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220930T154553Z:407d323c-b07f-409d-83d8-33a598250dbf", - "x-request-time": "0.122" + "x-ms-routing-request-id": "JAPANEAST:20221024T131313Z:9ebb3519-2e17-498f-abb7-763a516a7e38", + "x-request-time": "0.075" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -663,17 +663,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sas3vrosykmdp4s", - "containerName": "azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-29T22:16:05.5940148\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-29T22:16:06.5431636\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -687,7 +687,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -695,20 +695,20 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 15:45:53 GMT", + "Date": "Mon, 24 Oct 2022 13:13:13 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-4bde18244e325a9d3a3f185255808f86-b17091fc0d073b3a-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-ddcad1338e57a92d29f7caea19d57d8d-854b026f2dc4bd07-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "4a62cea1-a872-4c78-8c19-a04c77c1bf0f", - "x-ms-ratelimit-remaining-subscription-writes": "1164", + "x-ms-correlation-request-id": "38eebfa5-ee0e-4b95-8d0d-09a2984f9c7d", + "x-ms-ratelimit-remaining-subscription-writes": "1197", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220930T154553Z:4a62cea1-a872-4c78-8c19-a04c77c1bf0f", + "x-ms-routing-request-id": "JAPANEAST:20221024T131313Z:38eebfa5-ee0e-4b95-8d0d-09a2984f9c7d", "x-request-time": "0.090" }, "ResponseBody": { @@ -717,15 +717,15 @@ } }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/model/iris_model/MLmodel", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/model/iris_model/MLmodel", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Fri, 30 Sep 2022 15:45:53 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:13:13 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, @@ -734,9 +734,9 @@ "Content-Length": "298", "Content-MD5": "HaKpUL6X1WimkPVJF2lHiQ==", "Content-Type": "application/octet-stream", - "Date": "Fri, 30 Sep 2022 15:45:53 GMT", - "ETag": "\u00220x8DAA272A2EC747B\u0022", - "Last-Modified": "Thu, 29 Sep 2022 23:30:46 GMT", + "Date": "Mon, 24 Oct 2022 13:13:13 GMT", + "ETag": "\u00220x8DAB5ADA06F1E17\u0022", + "Last-Modified": "Mon, 24 Oct 2022 10:50:55 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -745,32 +745,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Thu, 29 Sep 2022 23:30:46 GMT", + "x-ms-creation-time": "Mon, 24 Oct 2022 10:50:53 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "844e4eb3-7920-4f7a-a28c-d8d891bcbf74", + "x-ms-meta-name": "9c212b41-a364-4c59-8722-2af33bd301d3", "x-ms-meta-upload_status": "completed", - "x-ms-meta-version": "28df3709-a44e-4b21-a884-fabc27dbed0d", + "x-ms-meta-version": "8eda34db-fb76-4dae-a634-f083a7f5f965", "x-ms-server-encrypted": "true", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/az-ml-artifacts/00000000000000000000000000000000/model/iris_model/MLmodel", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/model/iris_model/MLmodel", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Fri, 30 Sep 2022 15:45:53 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:13:14 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Fri, 30 Sep 2022 15:45:53 GMT", + "Date": "Mon, 24 Oct 2022 13:13:14 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -778,20 +778,20 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-06-01-preview", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "2261", + "Content-Length": "2285", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -823,7 +823,7 @@ "max_concurrency_per_instance": 2, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/c577b594-3497-4cd5-b811-dfe339626a6d/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/47ddf675-0155-4289-96eb-c37908b696c0/versions/1", "entry_script": "tabular_run_with_model.py", "program_arguments": "--model ${{inputs.score_model}}", "append_row_to": "${{outputs.job_out_path}}", @@ -847,10 +847,11 @@ "outputs": {}, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/afd38eb3-b2c4-49db-b1ad-2dc05e6031c2", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/234be6de-944e-4498-bdf4-e89058b5f16c", "retry_settings": null, "logging_level": null, - "mini_batch_size": 5 + "mini_batch_size": 5, + "partition_keys": null } }, "outputs": {}, @@ -863,22 +864,22 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "4543", + "Content-Length": "4613", "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 15:45:57 GMT", + "Date": "Mon, 24 Oct 2022 13:13:22 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-06-01-preview", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-bd5cf6a32308aba20a2720be811847fc-28c169b050769ae1-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-6231c6f82eb64c6d5bc60ca63f8891f9-d1de44ebf49e6bab-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "87515cc4-8870-4c98-9430-fd8fe863084d", - "x-ms-ratelimit-remaining-subscription-writes": "1104", + "x-ms-correlation-request-id": "4ad05173-2aa2-4ec6-beab-4d904225edfa", + "x-ms-ratelimit-remaining-subscription-writes": "1196", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220930T154557Z:87515cc4-8870-4c98-9430-fd8fe863084d", - "x-request-time": "2.602" + "x-ms-routing-request-id": "JAPANEAST:20221024T131323Z:4ad05173-2aa2-4ec6-beab-4d904225edfa", + "x-request-time": "4.666" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000", @@ -906,10 +907,11 @@ "Tracking": { "jobServiceType": "Tracking", "port": null, - "endpoint": "azureml://master.api.azureml-test.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", + "endpoint": "azureml://eastus2.api.azureml.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", "status": null, "errorMessage": null, - "properties": null + "properties": null, + "nodes": null }, "Studio": { "jobServiceType": "Studio", @@ -917,7 +919,8 @@ "endpoint": "https://ml.azure.com/runs/000000000000000000000?wsid=/subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000", "status": null, "errorMessage": null, - "properties": null + "properties": null, + "nodes": null } }, "computeId": null, @@ -939,7 +942,7 @@ "max_concurrency_per_instance": 2, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/c577b594-3497-4cd5-b811-dfe339626a6d/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/47ddf675-0155-4289-96eb-c37908b696c0/versions/1", "entry_script": "tabular_run_with_model.py", "program_arguments": "--model ${{inputs.score_model}}", "append_row_to": "${{outputs.job_out_path}}", @@ -963,10 +966,11 @@ "outputs": {}, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/afd38eb3-b2c4-49db-b1ad-2dc05e6031c2", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/234be6de-944e-4498-bdf4-e89058b5f16c", "retry_settings": null, "logging_level": null, - "mini_batch_size": 5 + "mini_batch_size": 5, + "partition_keys": null } }, "inputs": { @@ -987,21 +991,21 @@ "sourceJobId": null }, "systemData": { - "createdAt": "2022-09-30T15:45:57.1722261\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-10-24T13:13:22.986979\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User" } } }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000/cancel?api-version=2022-06-01-preview", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000/cancel?api-version=2022-10-01-preview", "RequestMethod": "POST", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 202, @@ -1009,81 +1013,50 @@ "Cache-Control": "no-cache", "Content-Length": "4", "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 15:46:00 GMT", + "Date": "Mon, 24 Oct 2022 13:13:25 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:86253a4f-a7a6-4008-8c86-ce9cf2978bc1:000000000000000000000?api-version=2022-06-01-preview", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/eastus2/mfeOperationResults/jc:e950f876-7257-4cf3-99a5-ff66812ac44c:000000000000000000000?api-version=2022-10-01-preview", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", "x-ms-async-operation-timeout": "PT1H", - "x-ms-correlation-request-id": "44c035be-038a-4712-acb1-03de3786bb90", - "x-ms-ratelimit-remaining-subscription-writes": "1163", + "x-ms-correlation-request-id": "8afd84b5-d5cc-47ac-8107-1d13653b0002", + "x-ms-ratelimit-remaining-subscription-writes": "1196", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220930T154600Z:44c035be-038a-4712-acb1-03de3786bb90", - "x-request-time": "1.726" + "x-ms-routing-request-id": "JAPANEAST:20221024T131326Z:8afd84b5-d5cc-47ac-8107-1d13653b0002", + "x-request-time": "0.573" }, "ResponseBody": "null" }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:86253a4f-a7a6-4008-8c86-ce9cf2978bc1:000000000000000000000?api-version=2022-06-01-preview", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/eastus2/mfeOperationResults/jc:e950f876-7257-4cf3-99a5-ff66812ac44c:000000000000000000000?api-version=2022-10-01-preview", "RequestMethod": "GET", "RequestHeaders": { "Accept": "*/*", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" - }, - "RequestBody": null, - "StatusCode": 202, - "ResponseHeaders": { - "Cache-Control": "no-cache", - "Content-Length": "2", - "Content-Type": "application/json; charset=utf-8", - "Date": "Fri, 30 Sep 2022 15:46:00 GMT", - "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:86253a4f-a7a6-4008-8c86-ce9cf2978bc1:000000000000000000000?api-version=2022-06-01-preview", - "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-01", - "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "0f5b99c4-2ac9-4fae-89bb-1510fe44b53e", - "x-ms-ratelimit-remaining-subscription-reads": "11942", - "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220930T154600Z:0f5b99c4-2ac9-4fae-89bb-1510fe44b53e", - "x-request-time": "0.110" - }, - "ResponseBody": {} - }, - { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/providers/Microsoft.MachineLearningServices/locations/centraluseuap/mfeOperationResults/jc:86253a4f-a7a6-4008-8c86-ce9cf2978bc1:000000000000000000000?api-version=2022-06-01-preview", - "RequestMethod": "GET", - "RequestHeaders": { - "Accept": "*/*", - "Accept-Encoding": "gzip, deflate", - "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", "Content-Length": "0", - "Date": "Fri, 30 Sep 2022 15:46:30 GMT", + "Date": "Mon, 24 Oct 2022 13:13:26 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-a63970b3effb46651117271ce4338eca-f30a13f409a798a0-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-0bbaa88e7e677cd3599efa16e6e6a7d8-9e3b58824a20c07d-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "1a7e6de6-f018-4b55-a3c7-ea68f87acdee", - "x-ms-ratelimit-remaining-subscription-reads": "11941", + "x-ms-correlation-request-id": "1bdcc060-81c2-4328-a4d0-4f2e33d1fe4e", + "x-ms-ratelimit-remaining-subscription-reads": "11996", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220930T154630Z:1a7e6de6-f018-4b55-a3c7-ea68f87acdee", - "x-request-time": "0.041" + "x-ms-routing-request-id": "JAPANEAST:20221024T131327Z:1bdcc060-81c2-4328-a4d0-4f2e33d1fe4e", + "x-request-time": "0.205" }, "ResponseBody": null } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline.pyTestDSLPipelinetest_parallel_run_function.json b/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline.pyTestDSLPipelinetest_parallel_run_function.json index 40a8b1d1cec8..3a4552e8c756 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline.pyTestDSLPipelinetest_parallel_run_function.json +++ b/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline.pyTestDSLPipelinetest_parallel_run_function.json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,24 +15,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:08 GMT", + "Date": "Tue, 25 Oct 2022 03:07:20 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-708f059c47326f63fea31f41bd56c9c8-abcdff6c1e9f58ed-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-2e828c91e64bfc0debd4ed896264af3c-7e07fb3bb583ea95-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "22952e34-e84c-468d-ac91-40e5cc2a07ca", - "x-ms-ratelimit-remaining-subscription-reads": "11941", + "x-ms-correlation-request-id": "4e34e877-6070-4b4b-8ad6-88f72b4db638", + "x-ms-ratelimit-remaining-subscription-reads": "11999", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233209Z:22952e34-e84c-468d-ac91-40e5cc2a07ca", - "x-request-time": "0.086" + "x-ms-routing-request-id": "JAPANEAST:20221025T030720Z:4e34e877-6070-4b4b-8ad6-88f72b4db638", + "x-request-time": "0.621" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -47,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sas3vrosykmdp4s", - "containerName": "azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-29T22:16:05.5940148\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-29T22:16:06.5431636\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -71,7 +71,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -79,21 +79,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:08 GMT", + "Date": "Tue, 25 Oct 2022 03:07:21 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-f4f1840613b2759dd1d6f2e88e8d02b4-bfb227003d971dd9-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-59dedd548264ab3fa761dc374bfa5be5-8135333fdcddd319-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "39049a34-1b7a-4d50-b3de-f0b2facfac89", - "x-ms-ratelimit-remaining-subscription-writes": "1161", + "x-ms-correlation-request-id": "9c94daea-1c49-402d-b926-c60c451eeb56", + "x-ms-ratelimit-remaining-subscription-writes": "1199", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233209Z:39049a34-1b7a-4d50-b3de-f0b2facfac89", - "x-request-time": "0.225" + "x-ms-routing-request-id": "JAPANEAST:20221025T030721Z:9c94daea-1c49-402d-b926-c60c451eeb56", + "x-request-time": "0.236" }, "ResponseBody": { "secretsType": "AccountKey", @@ -101,15 +101,15 @@ } }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 23:32:09 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:07:21 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, @@ -118,9 +118,9 @@ "Content-Length": "969", "Content-MD5": "DhunCanKGufSVuPKEYN51w==", "Content-Type": "application/octet-stream", - "Date": "Thu, 29 Sep 2022 23:32:08 GMT", - "ETag": "\u00220x8DAA272BA182BEE\u0022", - "Last-Modified": "Thu, 29 Sep 2022 23:31:25 GMT", + "Date": "Tue, 25 Oct 2022 03:07:22 GMT", + "ETag": "\u00220x8DA9D77F491F568\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:26:15 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -129,32 +129,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Thu, 29 Sep 2022 23:31:25 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:26:15 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "1992c9ec-9950-4a10-b848-21eccf196b5e", + "x-ms-meta-name": "55c9c168-236e-473f-b35e-c3cba03dad49", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 23:32:09 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:07:22 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Thu, 29 Sep 2022 23:32:08 GMT", + "Date": "Tue, 25 Oct 2022 03:07:22 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -162,12 +162,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -175,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -185,7 +185,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, @@ -193,27 +193,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:09 GMT", + "Date": "Tue, 25 Oct 2022 03:07:23 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-748fe032d878a630dbb0ca5c235485a9-4635c5d63fb02f37-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-2463d44e8be094dbd14d363e13360cc6-5a3cebe28e4c7ac0-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "52f22a67-4317-4fae-a22c-f8796ae18dc0", - "x-ms-ratelimit-remaining-subscription-writes": "1104", + "x-ms-correlation-request-id": "1851931d-cd59-4904-b901-875a24fa180c", + "x-ms-ratelimit-remaining-subscription-writes": "1199", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233210Z:52f22a67-4317-4fae-a22c-f8796ae18dc0", - "x-request-time": "0.207" + "x-ms-routing-request-id": "JAPANEAST:20221025T030723Z:1851931d-cd59-4904-b901-875a24fa180c", + "x-request-time": "0.643" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -225,14 +225,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-09-29T23:31:26.2712278\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-09-23T15:26:16.5278828\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-09-29T23:32:10.0656255\u002B00:00", - "lastModifiedBy": "Aditi Singhal", + "lastModifiedAt": "2022-10-25T03:07:23.623117\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -246,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "1148", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -284,7 +284,7 @@ "logging_level": "DEBUG", "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:5" @@ -301,26 +301,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2209", + "Content-Length": "2199", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:12 GMT", + "Date": "Tue, 25 Oct 2022 03:07:25 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-0fc91100124d33889158da2c0ae60ef0-b6b24e80056498d2-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-a74e96e8c0a087dbc0470ca446e8f267-04808da7f1b34f14-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "2e333a53-0484-4913-914e-4488c1594925", - "x-ms-ratelimit-remaining-subscription-writes": "1103", + "x-ms-correlation-request-id": "aeba454a-b50f-49eb-943c-b94c99b5cb5d", + "x-ms-ratelimit-remaining-subscription-writes": "1198", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233213Z:2e333a53-0484-4913-914e-4488c1594925", - "x-request-time": "3.464" + "x-ms-routing-request-id": "JAPANEAST:20221025T030725Z:aeba454a-b50f-49eb-943c-b94c99b5cb5d", + "x-request-time": "1.397" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/b5226dec-80b6-4eb0-bcb3-04148d75a9a0", - "name": "b5226dec-80b6-4eb0-bcb3-04148d75a9a0", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/f6c9fd47-f34d-4d25-bdff-4eb6bd580e1e", + "name": "f6c9fd47-f34d-4d25-bdff-4eb6bd580e1e", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -330,7 +330,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "b5226dec-80b6-4eb0-bcb3-04148d75a9a0", + "version": "f6c9fd47-f34d-4d25-bdff-4eb6bd580e1e", "display_name": "my-evaluate-job", "is_deterministic": "True", "type": "parallel", @@ -350,8 +350,8 @@ } }, "task": { - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/1992c9ec-9950-4a10-b848-21eccf196b5e/versions/1", - "environment": "azureml://registries/azureml-dev/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/5", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", + "environment": "azureml://registries/azureml/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/5", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "entry_script": "score.py", "type": "run_function" @@ -370,11 +370,11 @@ } }, "systemData": { - "createdAt": "2022-09-29T23:32:13.2729195\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-10-24T08:21:40.1641741\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-09-29T23:32:13.2729195\u002B00:00", - "lastModifiedBy": "Aditi Singhal", + "lastModifiedAt": "2022-10-24T08:21:40.3454311\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -386,7 +386,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -394,24 +394,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:14 GMT", + "Date": "Tue, 25 Oct 2022 03:07:26 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-46bc4ae2c28d008256a1fe5e40574ed5-4845f12e2c738f4e-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-3d6faba63b407f9aa70496e0278083fa-fbcc4f5762b6170a-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "75eecbc9-e724-46d7-b857-478c10c9298d", - "x-ms-ratelimit-remaining-subscription-reads": "11940", + "x-ms-correlation-request-id": "1798bfeb-ece0-448b-86cd-11be036d2772", + "x-ms-ratelimit-remaining-subscription-reads": "11998", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233214Z:75eecbc9-e724-46d7-b857-478c10c9298d", - "x-request-time": "0.090" + "x-ms-routing-request-id": "JAPANEAST:20221025T030726Z:1798bfeb-ece0-448b-86cd-11be036d2772", + "x-request-time": "0.073" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -426,17 +426,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sas3vrosykmdp4s", - "containerName": "azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-29T22:16:05.5940148\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-29T22:16:06.5431636\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -450,7 +450,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -458,21 +458,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:14 GMT", + "Date": "Tue, 25 Oct 2022 03:07:27 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-946c106e70bedf75e37ad5a887eb71ed-a8517d69253ffba9-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-d3ffee853ede8807d83b1ae1ac5750a1-ebec7da47e0d6c1c-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "8e7e6aa4-4df9-4dfd-bf6d-bd793ca25b60", - "x-ms-ratelimit-remaining-subscription-writes": "1160", + "x-ms-correlation-request-id": "ed6fae53-c1ef-49d4-a268-0268dccf4693", + "x-ms-ratelimit-remaining-subscription-writes": "1198", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233214Z:8e7e6aa4-4df9-4dfd-bf6d-bd793ca25b60", - "x-request-time": "0.424" + "x-ms-routing-request-id": "JAPANEAST:20221025T030727Z:ed6fae53-c1ef-49d4-a268-0268dccf4693", + "x-request-time": "0.115" }, "ResponseBody": { "secretsType": "AccountKey", @@ -480,15 +480,15 @@ } }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/LocalUpload/00000000000000000000000000000000/mnist-data/0.png", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/mnist-data/0.png", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 23:32:14 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:07:27 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, @@ -497,9 +497,9 @@ "Content-Length": "223", "Content-MD5": "yLW2CQQeldeN1S7hH1/5Nw==", "Content-Type": "application/octet-stream", - "Date": "Thu, 29 Sep 2022 23:32:13 GMT", - "ETag": "\u00220x8DAA272BD4B9081\u0022", - "Last-Modified": "Thu, 29 Sep 2022 23:31:31 GMT", + "Date": "Tue, 25 Oct 2022 03:07:27 GMT", + "ETag": "\u00220x8DA9D77C1560DE2\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:24:49 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -508,32 +508,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Thu, 29 Sep 2022 23:31:31 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:24:48 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "776195be-0520-410c-baf6-30d470c2ba98", + "x-ms-meta-name": "e6954628-b564-4b7e-bf0e-472284fbfa3f", "x-ms-meta-upload_status": "completed", - "x-ms-meta-version": "9e2621cd-06f1-4034-af15-7e796b2f5bb7", + "x-ms-meta-version": "c9aa34c9-8122-4239-abd0-25287b724051", "x-ms-server-encrypted": "true", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sas3vrosykmdp4s.blob.core.windows.net/azureml-blobstore-86253a4f-a7a6-4008-8c86-ce9cf2978bc1/az-ml-artifacts/00000000000000000000000000000000/mnist-data/0.png", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/mnist-data/0.png", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 23:32:14 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:07:27 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Thu, 29 Sep 2022 23:32:13 GMT", + "Date": "Tue, 25 Oct 2022 03:07:27 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -541,20 +541,20 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-06-01-preview", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "1819", + "Content-Length": "1843", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -608,10 +608,11 @@ }, "properties": {}, "_source": "BUILDER", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/b5226dec-80b6-4eb0-bcb3-04148d75a9a0", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/f6c9fd47-f34d-4d25-bdff-4eb6bd580e1e", "retry_settings": null, "logging_level": "DEBUG", - "mini_batch_size": 5 + "mini_batch_size": 5, + "partition_keys": null } }, "outputs": { @@ -628,22 +629,22 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "4176", + "Content-Length": "4247", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 23:32:19 GMT", + "Date": "Tue, 25 Oct 2022 03:07:38 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-06-01-preview", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-624762a0f811ce2a3339362c1ee7d784-b4bd0bfab69b80a4-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-2b0c33e65408b9e406c7ed855d7e4d12-b963591c610d798e-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "87945923-9e4b-405f-8519-76ee46ba124c", - "x-ms-ratelimit-remaining-subscription-writes": "1102", + "x-ms-correlation-request-id": "475ee5a1-5f92-4c96-b75c-cc6d11ef3d07", + "x-ms-ratelimit-remaining-subscription-writes": "1197", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T233219Z:87945923-9e4b-405f-8519-76ee46ba124c", - "x-request-time": "3.007" + "x-ms-routing-request-id": "JAPANEAST:20221025T030738Z:475ee5a1-5f92-4c96-b75c-cc6d11ef3d07", + "x-request-time": "4.203" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000", @@ -671,10 +672,11 @@ "Tracking": { "jobServiceType": "Tracking", "port": null, - "endpoint": "azureml://master.api.azureml-test.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", + "endpoint": "azureml://eastus2.api.azureml.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", "status": null, "errorMessage": null, - "properties": null + "properties": null, + "nodes": null }, "Studio": { "jobServiceType": "Studio", @@ -682,7 +684,8 @@ "endpoint": "https://ml.azure.com/runs/000000000000000000000?wsid=/subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000", "status": null, "errorMessage": null, - "properties": null + "properties": null, + "nodes": null } }, "computeId": null, @@ -731,10 +734,11 @@ }, "properties": {}, "_source": "BUILDER", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/b5226dec-80b6-4eb0-bcb3-04148d75a9a0", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/f6c9fd47-f34d-4d25-bdff-4eb6bd580e1e", "retry_settings": null, "logging_level": "DEBUG", - "mini_batch_size": 5 + "mini_batch_size": 5, + "partition_keys": null } }, "inputs": { @@ -756,8 +760,8 @@ "sourceJobId": null }, "systemData": { - "createdAt": "2022-09-29T23:32:18.9816675\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-10-25T03:07:38.0518894\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline_samples.pyTestDSLPipelineSamplestest_multi_parallel_components_with_file_input_pipeline_output.json b/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline_samples.pyTestDSLPipelineSamplestest_multi_parallel_components_with_file_input_pipeline_output.json index 401c7e9d59aa..90576b2d512e 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline_samples.pyTestDSLPipelineSamplestest_multi_parallel_components_with_file_input_pipeline_output.json +++ b/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline_samples.pyTestDSLPipelineSamplestest_multi_parallel_components_with_file_input_pipeline_output.json @@ -7,43 +7,47 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1512", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:06 GMT", + "Date": "Mon, 24 Oct 2022 13:22:01 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-c097c5abf522076b9d8831ed753c9d5a-e31c2a81271b0bd4-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-a3f926a1aae66cbc6ad2db63cbfd92d2-e1a2426175e09d27-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "eed8c5ea-41f4-411d-b046-cfdf31de381e", - "x-ms-ratelimit-remaining-subscription-reads": "11929", + "x-ms-correlation-request-id": "5b3fa8a1-99d7-4cef-92ec-59ed6a408fe1", + "x-ms-ratelimit-remaining-subscription-reads": "11998", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120407Z:eed8c5ea-41f4-411d-b046-cfdf31de381e", - "x-request-time": "0.225" + "x-ms-routing-request-id": "JAPANEAST:20221024T132202Z:5b3fa8a1-99d7-4cef-92ec-59ed6a408fe1", + "x-request-time": "0.056" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", "name": "cpu-cluster", "type": "Microsoft.MachineLearningServices/workspaces/computes", - "location": "centraluseuap", + "location": "eastus2", "tags": {}, "properties": { - "createdOn": "2022-09-22T09:02:22.1899959\u002B00:00", - "modifiedOn": "2022-09-23T03:28:18.0066218\u002B00:00", + "createdOn": "2022-09-22T03:07:49.0785672\u002B00:00", + "modifiedOn": "2022-10-11T04:29:30.5828273\u002B00:00", "disableLocalAuth": false, "description": null, "resourceId": null, "computeType": "AmlCompute", - "computeLocation": "centraluseuap", + "computeLocation": "eastus2", "provisioningState": "Succeeded", "provisioningErrors": null, "isAttachedCompute": false, @@ -52,22 +56,22 @@ "vmPriority": "Dedicated", "scaleSettings": { "maxNodeCount": 4, - "minNodeCount": 1, + "minNodeCount": 0, "nodeIdleTimeBeforeScaleDown": "PT2M" }, "subnet": null, - "currentNodeCount": 1, - "targetNodeCount": 1, + "currentNodeCount": 0, + "targetNodeCount": 2, "nodeStateCounts": { "preparingNodeCount": 0, "runningNodeCount": 0, - "idleNodeCount": 1, + "idleNodeCount": 0, "unusableNodeCount": 0, "leavingNodeCount": 0, "preemptedNodeCount": 0 }, - "allocationState": "Steady", - "allocationStateTransitionTime": "2022-09-30T08:08:43.647\u002B00:00", + "allocationState": "Resizing", + "allocationStateTransitionTime": "2022-10-24T13:18:52.65\u002B00:00", "errors": null, "remoteLoginPortPublicAccess": "Enabled", "osType": "Linux", @@ -85,43 +89,47 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1512", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:07 GMT", + "Date": "Mon, 24 Oct 2022 13:22:02 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-aad0b92f9718bdb4db6cf3f7d4e148a1-fd051cb626b35dad-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-42310cc515e1862dc588ac949ce7a5b7-a9c6c16736307318-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "6160794d-b2d3-442d-89cc-db2bdb2f7cf7", - "x-ms-ratelimit-remaining-subscription-reads": "11928", + "x-ms-correlation-request-id": "bd0a93f3-f56c-4524-b71e-023dcdbc3251", + "x-ms-ratelimit-remaining-subscription-reads": "11997", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120408Z:6160794d-b2d3-442d-89cc-db2bdb2f7cf7", - "x-request-time": "0.230" + "x-ms-routing-request-id": "JAPANEAST:20221024T132202Z:bd0a93f3-f56c-4524-b71e-023dcdbc3251", + "x-request-time": "0.047" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", "name": "cpu-cluster", "type": "Microsoft.MachineLearningServices/workspaces/computes", - "location": "centraluseuap", + "location": "eastus2", "tags": {}, "properties": { - "createdOn": "2022-09-22T09:02:22.1899959\u002B00:00", - "modifiedOn": "2022-09-23T03:28:18.0066218\u002B00:00", + "createdOn": "2022-09-22T03:07:49.0785672\u002B00:00", + "modifiedOn": "2022-10-11T04:29:30.5828273\u002B00:00", "disableLocalAuth": false, "description": null, "resourceId": null, "computeType": "AmlCompute", - "computeLocation": "centraluseuap", + "computeLocation": "eastus2", "provisioningState": "Succeeded", "provisioningErrors": null, "isAttachedCompute": false, @@ -130,22 +138,22 @@ "vmPriority": "Dedicated", "scaleSettings": { "maxNodeCount": 4, - "minNodeCount": 1, + "minNodeCount": 0, "nodeIdleTimeBeforeScaleDown": "PT2M" }, "subnet": null, - "currentNodeCount": 1, - "targetNodeCount": 1, + "currentNodeCount": 0, + "targetNodeCount": 2, "nodeStateCounts": { "preparingNodeCount": 0, "runningNodeCount": 0, - "idleNodeCount": 1, + "idleNodeCount": 0, "unusableNodeCount": 0, "leavingNodeCount": 0, "preemptedNodeCount": 0 }, - "allocationState": "Steady", - "allocationStateTransitionTime": "2022-09-30T08:08:43.647\u002B00:00", + "allocationState": "Resizing", + "allocationStateTransitionTime": "2022-10-24T13:18:52.65\u002B00:00", "errors": null, "remoteLoginPortPublicAccess": "Enabled", "osType": "Linux", @@ -163,43 +171,47 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1512", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:07 GMT", + "Date": "Mon, 24 Oct 2022 13:22:02 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-873a8d2bd386f0ae41db51da1d45a4c4-85ce2af77000caec-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-c32d05b432a1e334d5a2ba2886a8066c-308b9978ff993396-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "e664558e-d7f1-4ead-928a-9f8d181f9c06", - "x-ms-ratelimit-remaining-subscription-reads": "11927", + "x-ms-correlation-request-id": "2bd7e7e6-6887-4033-8577-c03000f602b3", + "x-ms-ratelimit-remaining-subscription-reads": "11996", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120408Z:e664558e-d7f1-4ead-928a-9f8d181f9c06", - "x-request-time": "0.249" + "x-ms-routing-request-id": "JAPANEAST:20221024T132203Z:2bd7e7e6-6887-4033-8577-c03000f602b3", + "x-request-time": "0.036" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", "name": "cpu-cluster", "type": "Microsoft.MachineLearningServices/workspaces/computes", - "location": "centraluseuap", + "location": "eastus2", "tags": {}, "properties": { - "createdOn": "2022-09-22T09:02:22.1899959\u002B00:00", - "modifiedOn": "2022-09-23T03:28:18.0066218\u002B00:00", + "createdOn": "2022-09-22T03:07:49.0785672\u002B00:00", + "modifiedOn": "2022-10-11T04:29:30.5828273\u002B00:00", "disableLocalAuth": false, "description": null, "resourceId": null, "computeType": "AmlCompute", - "computeLocation": "centraluseuap", + "computeLocation": "eastus2", "provisioningState": "Succeeded", "provisioningErrors": null, "isAttachedCompute": false, @@ -208,22 +220,22 @@ "vmPriority": "Dedicated", "scaleSettings": { "maxNodeCount": 4, - "minNodeCount": 1, + "minNodeCount": 0, "nodeIdleTimeBeforeScaleDown": "PT2M" }, "subnet": null, - "currentNodeCount": 1, - "targetNodeCount": 1, + "currentNodeCount": 0, + "targetNodeCount": 2, "nodeStateCounts": { "preparingNodeCount": 0, "runningNodeCount": 0, - "idleNodeCount": 1, + "idleNodeCount": 0, "unusableNodeCount": 0, "leavingNodeCount": 0, "preemptedNodeCount": 0 }, - "allocationState": "Steady", - "allocationStateTransitionTime": "2022-09-30T08:08:43.647\u002B00:00", + "allocationState": "Resizing", + "allocationStateTransitionTime": "2022-10-24T13:18:52.65\u002B00:00", "errors": null, "remoteLoginPortPublicAccess": "Enabled", "osType": "Linux", @@ -241,28 +253,32 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1067", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:11 GMT", + "Date": "Mon, 24 Oct 2022 13:22:06 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-c152b801a599e5d107c6bfd43936010d-a82cf3d05c4147e2-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-8eb5c048d783a263701d97f8767339bf-7335d619952fbff2-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "e82cd1f3-03ce-481d-b47e-a36fe75d3d5f", - "x-ms-ratelimit-remaining-subscription-reads": "11926", + "x-ms-correlation-request-id": "4b43cedf-f4b4-4320-835c-bf115c5fbbe6", + "x-ms-ratelimit-remaining-subscription-reads": "11995", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120411Z:e82cd1f3-03ce-481d-b47e-a36fe75d3d5f", - "x-request-time": "0.151" + "x-ms-routing-request-id": "JAPANEAST:20221024T132206Z:4b43cedf-f4b4-4320-835c-bf115c5fbbe6", + "x-request-time": "0.072" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -277,17 +293,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -301,27 +317,29 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "61", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:12 GMT", + "Date": "Mon, 24 Oct 2022 13:22:07 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-c7c712b412aaf00e63eeb897a68edf4a-97859724bb0fb77d-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-b53e3be0464d5d8685a9eb2b2bb4d97f-f7e85527dc7976be-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "c6ba969d-d4a7-4605-8c8c-2fead3820765", - "x-ms-ratelimit-remaining-subscription-writes": "1160", + "x-ms-correlation-request-id": "692968a5-fa02-4e0e-a7d3-f803dc9729d0", + "x-ms-ratelimit-remaining-subscription-writes": "1199", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120412Z:c6ba969d-d4a7-4605-8c8c-2fead3820765", - "x-request-time": "0.122" + "x-ms-routing-request-id": "JAPANEAST:20221024T132207Z:692968a5-fa02-4e0e-a7d3-f803dc9729d0", + "x-request-time": "0.164" }, "ResponseBody": { "secretsType": "AccountKey", @@ -329,14 +347,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:04:12 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:22:07 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -346,9 +364,9 @@ "Content-Length": "969", "Content-MD5": "DhunCanKGufSVuPKEYN51w==", "Content-Type": "application/octet-stream", - "Date": "Wed, 12 Oct 2022 12:04:12 GMT", - "ETag": "\u00220x8DA9D4A193DC816\u0022", - "Last-Modified": "Fri, 23 Sep 2022 09:58:00 GMT", + "Date": "Mon, 24 Oct 2022 13:22:08 GMT", + "ETag": "\u00220x8DA9D77F491F568\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:26:15 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -357,10 +375,10 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Fri, 23 Sep 2022 09:57:59 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:26:15 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "3af49689-e732-4d3f-9854-43df40223df3", + "x-ms-meta-name": "55c9c168-236e-473f-b35e-c3cba03dad49", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", @@ -369,20 +387,20 @@ "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:04:12 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:22:08 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Wed, 12 Oct 2022 12:04:12 GMT", + "Date": "Mon, 24 Oct 2022 13:22:08 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -395,7 +413,7 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -403,7 +421,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -413,31 +431,35 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "818", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:13 GMT", + "Date": "Mon, 24 Oct 2022 13:22:10 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-70a87a0d1a07e4e06bf9bde4989eb108-b17aa14a209e7fe0-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-68c9ed15b2940d300f479ea06f4f4e30-6a80e6a4fc09a4cb-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "9fa10c9a-bfdb-410a-8d75-1d9dd615ef4a", - "x-ms-ratelimit-remaining-subscription-writes": "1115", + "x-ms-correlation-request-id": "c37a891e-df38-44f5-b44d-62d4ed863e38", + "x-ms-ratelimit-remaining-subscription-writes": "1199", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120413Z:9fa10c9a-bfdb-410a-8d75-1d9dd615ef4a", - "x-request-time": "0.211" + "x-ms-routing-request-id": "JAPANEAST:20221024T132211Z:c37a891e-df38-44f5-b44d-62d4ed863e38", + "x-request-time": "0.160" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -449,14 +471,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-09-23T09:58:01.1651738\u002B00:00", - "createdBy": "Ying Chen", + "createdAt": "2022-09-23T15:26:16.5278828\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-10-12T12:04:13.0496052\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-24T13:22:10.8206301\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -470,7 +492,7 @@ "Connection": "keep-alive", "Content-Length": "1202", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -504,7 +526,7 @@ }, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -520,26 +542,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2209", + "Content-Length": "2199", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:15 GMT", + "Date": "Mon, 24 Oct 2022 13:22:12 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-7b313908462ed7afa5cc70b7624659f7-82a090b8a15fd6bc-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-f1101d4f468fe0741b4b7430d5af79e2-15d8dbd05c74d23a-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "221f2d2a-70cf-4f55-a337-3ad3efe4f38a", - "x-ms-ratelimit-remaining-subscription-writes": "1114", + "x-ms-correlation-request-id": "055fcfec-3b96-4f78-90f8-024b9bb32051", + "x-ms-ratelimit-remaining-subscription-writes": "1198", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120415Z:221f2d2a-70cf-4f55-a337-3ad3efe4f38a", - "x-request-time": "1.204" + "x-ms-routing-request-id": "JAPANEAST:20221024T132212Z:055fcfec-3b96-4f78-90f8-024b9bb32051", + "x-request-time": "0.584" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/b6a05c03-ad84-46ce-b326-ecc8c5d44726", - "name": "b6a05c03-ad84-46ce-b326-ecc8c5d44726", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0b7f72b4-52b8-413f-98fb-67b989a06598", + "name": "0b7f72b4-52b8-413f-98fb-67b989a06598", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -549,7 +571,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "b6a05c03-ad84-46ce-b326-ecc8c5d44726", + "version": "0b7f72b4-52b8-413f-98fb-67b989a06598", "display_name": "BatchScore", "is_deterministic": "True", "type": "parallel", @@ -567,8 +589,8 @@ } }, "task": { - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", - "environment": "azureml://registries/azureml-dev/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", + "environment": "azureml://registries/azureml/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "entry_script": "score.py", "type": "run_function" @@ -587,11 +609,11 @@ } }, "systemData": { - "createdAt": "2022-10-12T11:41:10.7336842\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-10-24T08:21:17.0116182\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-10-12T11:41:11.2470066\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-24T08:21:17.1720572\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -603,28 +625,32 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1067", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:15 GMT", + "Date": "Mon, 24 Oct 2022 13:22:13 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-cf2fb1de478b715d26314e3d2c16191e-312039774fb4296f-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-6cb831bc157e09e2b61c1de3ceb14c35-1b48ba8533885de7-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "a98fa6e1-04e1-4c3f-873b-2ccef37cd4da", - "x-ms-ratelimit-remaining-subscription-reads": "11925", + "x-ms-correlation-request-id": "cd568ad8-6726-4d24-905b-79dcfeeb08f2", + "x-ms-ratelimit-remaining-subscription-reads": "11994", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120415Z:a98fa6e1-04e1-4c3f-873b-2ccef37cd4da", - "x-request-time": "0.152" + "x-ms-routing-request-id": "JAPANEAST:20221024T132213Z:cd568ad8-6726-4d24-905b-79dcfeeb08f2", + "x-request-time": "0.081" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -639,17 +665,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -663,27 +689,29 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "61", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:16 GMT", + "Date": "Mon, 24 Oct 2022 13:22:14 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-4e9ed2ecf9b74f6b9e5e79c639175ce4-2bca3a63676e6034-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-a9af123a885d2fae873ea6e1c39630e9-652a902ca07aea0d-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "d082201b-e990-4af6-ba51-36ea82a6cdc2", - "x-ms-ratelimit-remaining-subscription-writes": "1159", + "x-ms-correlation-request-id": "84859086-2715-42bd-bb5c-7d50baac4e63", + "x-ms-ratelimit-remaining-subscription-writes": "1198", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120416Z:d082201b-e990-4af6-ba51-36ea82a6cdc2", - "x-request-time": "0.159" + "x-ms-routing-request-id": "JAPANEAST:20221024T132214Z:84859086-2715-42bd-bb5c-7d50baac4e63", + "x-request-time": "0.100" }, "ResponseBody": { "secretsType": "AccountKey", @@ -691,14 +719,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:04:16 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:22:14 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -708,9 +736,9 @@ "Content-Length": "969", "Content-MD5": "DhunCanKGufSVuPKEYN51w==", "Content-Type": "application/octet-stream", - "Date": "Wed, 12 Oct 2022 12:04:16 GMT", - "ETag": "\u00220x8DA9D4A193DC816\u0022", - "Last-Modified": "Fri, 23 Sep 2022 09:58:00 GMT", + "Date": "Mon, 24 Oct 2022 13:22:14 GMT", + "ETag": "\u00220x8DA9D77F491F568\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:26:15 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -719,10 +747,10 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Fri, 23 Sep 2022 09:57:59 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:26:15 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "3af49689-e732-4d3f-9854-43df40223df3", + "x-ms-meta-name": "55c9c168-236e-473f-b35e-c3cba03dad49", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", @@ -731,20 +759,20 @@ "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:04:16 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:22:14 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Wed, 12 Oct 2022 12:04:16 GMT", + "Date": "Mon, 24 Oct 2022 13:22:14 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -757,7 +785,7 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -765,7 +793,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -775,31 +803,35 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "818", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:17 GMT", + "Date": "Mon, 24 Oct 2022 13:22:15 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-ef63c16f4742bdf0c4b5dba7b9f89cfd-648a9b91295fe2fe-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-fa7470f0aadf650b695dcf53210ddbe6-1033d50d6280afd9-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "8924d72a-7a88-499b-8eed-92cac2dfe1b1", - "x-ms-ratelimit-remaining-subscription-writes": "1113", + "x-ms-correlation-request-id": "6ba5b42b-0878-4a0f-8e86-46a2a6d10daa", + "x-ms-ratelimit-remaining-subscription-writes": "1197", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120417Z:8924d72a-7a88-499b-8eed-92cac2dfe1b1", - "x-request-time": "0.187" + "x-ms-routing-request-id": "JAPANEAST:20221024T132215Z:6ba5b42b-0878-4a0f-8e86-46a2a6d10daa", + "x-request-time": "0.062" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -811,14 +843,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-09-23T09:58:01.1651738\u002B00:00", - "createdBy": "Ying Chen", + "createdAt": "2022-09-23T15:26:16.5278828\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-10-12T12:04:17.4204565\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-24T13:22:15.7262874\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -832,7 +864,7 @@ "Connection": "keep-alive", "Content-Length": "809", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -842,7 +874,7 @@ "isArchived": false, "componentSpec": { "command": "python convert_data.py --input_data ${{inputs.input_data}} --file_output_data ${{outputs.file_output_data}}", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:5", "name": "azureml_anonymous", "tags": {}, @@ -867,26 +899,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1818", + "Content-Length": "1807", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:19 GMT", + "Date": "Mon, 24 Oct 2022 13:22:16 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-d47fb9ed0ca0e3bedac6e97940fc68d8-ce666a38cbd684a8-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-685b1aa4404b437a66285a1496d0933d-92a5476d99f8b6fa-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "93012a7b-6d2b-47f5-be60-4b11018c24fb", - "x-ms-ratelimit-remaining-subscription-writes": "1112", + "x-ms-correlation-request-id": "89d5a5ed-3052-42a5-8489-d568ae4ac705", + "x-ms-ratelimit-remaining-subscription-writes": "1196", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120419Z:93012a7b-6d2b-47f5-be60-4b11018c24fb", - "x-request-time": "1.374" + "x-ms-routing-request-id": "JAPANEAST:20221024T132216Z:89d5a5ed-3052-42a5-8489-d568ae4ac705", + "x-request-time": "0.465" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/dbec396a-6efe-4dd2-b9d8-a9f71b7b91c5", - "name": "dbec396a-6efe-4dd2-b9d8-a9f71b7b91c5", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/4cee2689-473d-4df7-b018-ac2397b5d257", + "name": "4cee2689-473d-4df7-b018-ac2397b5d257", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -896,7 +928,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "dbec396a-6efe-4dd2-b9d8-a9f71b7b91c5", + "version": "4cee2689-473d-4df7-b018-ac2397b5d257", "display_name": "Convert_To_Mltable_File_Dataset", "is_deterministic": "True", "type": "command", @@ -911,8 +943,8 @@ "type": "mltable" } }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", - "environment": "azureml://registries/azureml-dev/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/5", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", + "environment": "azureml://registries/azureml/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/5", "resources": { "instance_count": "1" }, @@ -921,11 +953,11 @@ } }, "systemData": { - "createdAt": "2022-10-12T11:41:15.5052488\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-10-24T09:48:39.678435\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-10-12T11:41:15.9999121\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-24T09:48:39.8575283\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -937,28 +969,32 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1067", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:20 GMT", + "Date": "Mon, 24 Oct 2022 13:22:17 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-703f819ec0bb4982eac221c966297e3c-5c8f564c2fd2ad00-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-b121baa205c6d33042579893f26f386a-24f13ec7b9519b00-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "f6afc37f-ad38-45c9-a9d7-aab101659c75", - "x-ms-ratelimit-remaining-subscription-reads": "11924", + "x-ms-correlation-request-id": "516ca62c-d53a-4f73-8101-d93fdb48cb2f", + "x-ms-ratelimit-remaining-subscription-reads": "11993", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120420Z:f6afc37f-ad38-45c9-a9d7-aab101659c75", - "x-request-time": "0.158" + "x-ms-routing-request-id": "JAPANEAST:20221024T132217Z:516ca62c-d53a-4f73-8101-d93fdb48cb2f", + "x-request-time": "0.082" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -973,17 +1009,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -997,27 +1033,29 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "61", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:20 GMT", + "Date": "Mon, 24 Oct 2022 13:22:17 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-6aa9e429eaf793ff7c1beee3f4032557-8212d8f47f976799-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-7261695248c30a827852014af1fd4ef6-0f029acea8be8a73-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "438dddb6-f11a-4a4d-9609-cd76b4f6d240", - "x-ms-ratelimit-remaining-subscription-writes": "1158", + "x-ms-correlation-request-id": "dd2bde5b-a857-46ad-af5c-67ea8ab3b64e", + "x-ms-ratelimit-remaining-subscription-writes": "1197", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120420Z:438dddb6-f11a-4a4d-9609-cd76b4f6d240", - "x-request-time": "0.202" + "x-ms-routing-request-id": "JAPANEAST:20221024T132218Z:dd2bde5b-a857-46ad-af5c-67ea8ab3b64e", + "x-request-time": "0.089" }, "ResponseBody": { "secretsType": "AccountKey", @@ -1025,14 +1063,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:04:20 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:22:18 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -1042,9 +1080,9 @@ "Content-Length": "969", "Content-MD5": "DhunCanKGufSVuPKEYN51w==", "Content-Type": "application/octet-stream", - "Date": "Wed, 12 Oct 2022 12:04:20 GMT", - "ETag": "\u00220x8DA9D4A193DC816\u0022", - "Last-Modified": "Fri, 23 Sep 2022 09:58:00 GMT", + "Date": "Mon, 24 Oct 2022 13:22:18 GMT", + "ETag": "\u00220x8DA9D77F491F568\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:26:15 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -1053,10 +1091,10 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Fri, 23 Sep 2022 09:57:59 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:26:15 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "3af49689-e732-4d3f-9854-43df40223df3", + "x-ms-meta-name": "55c9c168-236e-473f-b35e-c3cba03dad49", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", @@ -1065,20 +1103,20 @@ "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:04:21 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:22:18 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Wed, 12 Oct 2022 12:04:20 GMT", + "Date": "Mon, 24 Oct 2022 13:22:18 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -1091,7 +1129,7 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -1099,7 +1137,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -1109,31 +1147,35 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "818", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:21 GMT", + "Date": "Mon, 24 Oct 2022 13:22:19 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-2e93f78987deb15afbcbcf1600c2553b-39593c18349a7867-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-80001b906cf5dcf73f66afd7473c0aa7-84f620c2c9087db2-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "7c7c5347-28e0-46d3-841e-6efa6e618d5a", - "x-ms-ratelimit-remaining-subscription-writes": "1111", + "x-ms-correlation-request-id": "17d12674-8621-4055-99a7-61d7b388262a", + "x-ms-ratelimit-remaining-subscription-writes": "1195", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120421Z:7c7c5347-28e0-46d3-841e-6efa6e618d5a", - "x-request-time": "0.188" + "x-ms-routing-request-id": "JAPANEAST:20221024T132220Z:17d12674-8621-4055-99a7-61d7b388262a", + "x-request-time": "0.068" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -1145,14 +1187,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-09-23T09:58:01.1651738\u002B00:00", - "createdBy": "Ying Chen", + "createdAt": "2022-09-23T15:26:16.5278828\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-10-12T12:04:21.6302387\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-24T13:22:20.1468987\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -1166,7 +1208,7 @@ "Connection": "keep-alive", "Content-Length": "1202", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -1200,7 +1242,7 @@ }, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -1216,26 +1258,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2209", + "Content-Length": "2199", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:23 GMT", + "Date": "Mon, 24 Oct 2022 13:22:20 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-c79aeb56f010db4e35002227eaca2d73-46de0499b59d968c-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-17136f64ea9f674065e7b5b403927a57-b9114ab71b504549-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "a0a6d35a-b95b-4ce9-ad1d-0ec55fbc719d", - "x-ms-ratelimit-remaining-subscription-writes": "1110", + "x-ms-correlation-request-id": "f161563e-d527-4a61-862e-8ed256e867cd", + "x-ms-ratelimit-remaining-subscription-writes": "1194", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120423Z:a0a6d35a-b95b-4ce9-ad1d-0ec55fbc719d", - "x-request-time": "1.338" + "x-ms-routing-request-id": "JAPANEAST:20221024T132221Z:f161563e-d527-4a61-862e-8ed256e867cd", + "x-request-time": "0.454" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/b6a05c03-ad84-46ce-b326-ecc8c5d44726", - "name": "b6a05c03-ad84-46ce-b326-ecc8c5d44726", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0b7f72b4-52b8-413f-98fb-67b989a06598", + "name": "0b7f72b4-52b8-413f-98fb-67b989a06598", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -1245,7 +1287,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "b6a05c03-ad84-46ce-b326-ecc8c5d44726", + "version": "0b7f72b4-52b8-413f-98fb-67b989a06598", "display_name": "BatchScore", "is_deterministic": "True", "type": "parallel", @@ -1263,8 +1305,8 @@ } }, "task": { - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", - "environment": "azureml://registries/azureml-dev/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", + "environment": "azureml://registries/azureml/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "entry_script": "score.py", "type": "run_function" @@ -1283,11 +1325,11 @@ } }, "systemData": { - "createdAt": "2022-10-12T11:41:10.7336842\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-10-24T08:21:17.0116182\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-10-12T11:41:11.2470066\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-24T08:21:17.1720572\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -1299,28 +1341,32 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1067", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:24 GMT", + "Date": "Mon, 24 Oct 2022 13:22:21 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-5f6493867204bec53793bd581396bd56-6a18649139b9302c-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-42b2a5ef01142be9fcee59356a68e792-a9046b68d2a4cb7e-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "147b9cb4-daee-4d12-89c4-194bb422781c", - "x-ms-ratelimit-remaining-subscription-reads": "11923", + "x-ms-correlation-request-id": "a1bfefdc-15c4-45fc-96bc-7a522b8c9f4b", + "x-ms-ratelimit-remaining-subscription-reads": "11992", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120424Z:147b9cb4-daee-4d12-89c4-194bb422781c", - "x-request-time": "0.106" + "x-ms-routing-request-id": "JAPANEAST:20221024T132222Z:a1bfefdc-15c4-45fc-96bc-7a522b8c9f4b", + "x-request-time": "0.091" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -1335,17 +1381,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -1359,27 +1405,29 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "61", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:24 GMT", + "Date": "Mon, 24 Oct 2022 13:22:22 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-14e5ac1bb68023e64204a2ccdaf94dd9-5a80b2fb30fac159-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-4f7c09f67de68ebb71362470bb093b65-b16367eac299065f-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "54648f7e-13bf-4c98-9dfb-802df508dbe5", - "x-ms-ratelimit-remaining-subscription-writes": "1157", + "x-ms-correlation-request-id": "f8360489-1228-49be-aa6e-1588e2fb813f", + "x-ms-ratelimit-remaining-subscription-writes": "1196", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120424Z:54648f7e-13bf-4c98-9dfb-802df508dbe5", - "x-request-time": "0.125" + "x-ms-routing-request-id": "JAPANEAST:20221024T132223Z:f8360489-1228-49be-aa6e-1588e2fb813f", + "x-request-time": "0.148" }, "ResponseBody": { "secretsType": "AccountKey", @@ -1387,14 +1435,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/mnist-data/0.png", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/mnist-data/0.png", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:04:24 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:22:23 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -1404,9 +1452,9 @@ "Content-Length": "223", "Content-MD5": "yLW2CQQeldeN1S7hH1/5Nw==", "Content-Type": "application/octet-stream", - "Date": "Wed, 12 Oct 2022 12:04:24 GMT", - "ETag": "\u00220x8DA9D49DDA8E2B9\u0022", - "Last-Modified": "Fri, 23 Sep 2022 09:56:20 GMT", + "Date": "Mon, 24 Oct 2022 13:22:22 GMT", + "ETag": "\u00220x8DA9D77C1560DE2\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:24:49 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -1415,32 +1463,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Fri, 23 Sep 2022 09:56:19 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:24:48 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "6d38069b-69f7-4247-bed0-fffe996f3098", + "x-ms-meta-name": "e6954628-b564-4b7e-bf0e-472284fbfa3f", "x-ms-meta-upload_status": "completed", - "x-ms-meta-version": "315ab246-e719-41ed-9ad8-28f2f315a8e2", + "x-ms-meta-version": "c9aa34c9-8122-4239-abd0-25287b724051", "x-ms-server-encrypted": "true", "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/mnist-data/0.png", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/mnist-data/0.png", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:04:24 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:22:23 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Wed, 12 Oct 2022 12:04:24 GMT", + "Date": "Mon, 24 Oct 2022 13:22:23 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -1459,9 +1507,9 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "4264", + "Content-Length": "4312", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -1492,7 +1540,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -1511,10 +1559,11 @@ "outputs": {}, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/b6a05c03-ad84-46ce-b326-ecc8c5d44726", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0b7f72b4-52b8-413f-98fb-67b989a06598", "retry_settings": null, "logging_level": null, - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null }, "convert_data_node": { "resources": null, @@ -1539,7 +1588,7 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/dbec396a-6efe-4dd2-b9d8-a9f71b7b91c5" + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/4cee2689-473d-4df7-b018-ac2397b5d257" }, "file_batch_inference_duplicate_node": { "type": "parallel", @@ -1553,7 +1602,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -1578,10 +1627,11 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/b6a05c03-ad84-46ce-b326-ecc8c5d44726", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0b7f72b4-52b8-413f-98fb-67b989a06598", "retry_settings": null, "logging_level": null, - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null } }, "outputs": { @@ -1598,22 +1648,22 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "7174", + "Content-Length": "7231", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:33 GMT", + "Date": "Mon, 24 Oct 2022 13:22:33 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-5ec3cd909fdc923d7f133c05ded04e6a-966f43d1c41ee456-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-7f93eceea644ebea936047984c159c11-bc6a3d728c08fe49-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "583e3b6a-87eb-478f-b725-8577a7ee9bcc", - "x-ms-ratelimit-remaining-subscription-writes": "1109", + "x-ms-correlation-request-id": "bac49fb1-c63d-4e9b-846e-7a3ad23e50e6", + "x-ms-ratelimit-remaining-subscription-writes": "1193", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120433Z:583e3b6a-87eb-478f-b725-8577a7ee9bcc", - "x-request-time": "3.564" + "x-ms-routing-request-id": "JAPANEAST:20221024T132234Z:bac49fb1-c63d-4e9b-846e-7a3ad23e50e6", + "x-request-time": "4.769" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000", @@ -1641,7 +1691,7 @@ "Tracking": { "jobServiceType": "Tracking", "port": null, - "endpoint": "azureml://master.api.azureml-test.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", + "endpoint": "azureml://eastus2.api.azureml.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", "status": null, "errorMessage": null, "properties": null, @@ -1678,7 +1728,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -1697,10 +1747,11 @@ "outputs": {}, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/b6a05c03-ad84-46ce-b326-ecc8c5d44726", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0b7f72b4-52b8-413f-98fb-67b989a06598", "retry_settings": null, "logging_level": null, - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null }, "convert_data_node": { "resources": null, @@ -1725,7 +1776,7 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/dbec396a-6efe-4dd2-b9d8-a9f71b7b91c5" + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/4cee2689-473d-4df7-b018-ac2397b5d257" }, "file_batch_inference_duplicate_node": { "type": "parallel", @@ -1739,7 +1790,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/3af49689-e732-4d3f-9854-43df40223df3/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -1764,10 +1815,11 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/b6a05c03-ad84-46ce-b326-ecc8c5d44726", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/0b7f72b4-52b8-413f-98fb-67b989a06598", "retry_settings": null, "logging_level": null, - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null } }, "inputs": { @@ -1789,8 +1841,8 @@ "sourceJobId": null }, "systemData": { - "createdAt": "2022-10-12T12:04:32.5483046\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-10-24T13:22:33.6335472\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline_samples.pyTestDSLPipelineSamplestest_parallel_components.json b/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline_samples.pyTestDSLPipelineSamplestest_parallel_components.json index 56de6a276891..844dce145894 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline_samples.pyTestDSLPipelineSamplestest_parallel_components.json +++ b/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline_samples.pyTestDSLPipelineSamplestest_parallel_components.json @@ -7,28 +7,32 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1067", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:13 GMT", + "Date": "Tue, 25 Oct 2022 03:16:23 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-c9e3bc27c65b358a2e1b159300acf8d9-7e733c522e986554-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-8a33f57251b54b8e3dcd04c75acb1635-867aedb5110afa54-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "ef931f5e-361f-4a9d-bf29-d41073fc8015", - "x-ms-ratelimit-remaining-subscription-reads": "11918", + "x-ms-correlation-request-id": "1b39832c-f9f7-4103-9313-0659e08051d4", + "x-ms-ratelimit-remaining-subscription-reads": "11990", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120513Z:ef931f5e-361f-4a9d-bf29-d41073fc8015", - "x-request-time": "0.104" + "x-ms-routing-request-id": "JAPANEAST:20221025T031624Z:1b39832c-f9f7-4103-9313-0659e08051d4", + "x-request-time": "0.078" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -43,17 +47,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -67,27 +71,29 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "61", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:13 GMT", + "Date": "Tue, 25 Oct 2022 03:16:24 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-de18ec0bd941a175136ed8f94006de0e-4864a9b01286deee-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-616f97b525899a9eeceb96fd32ad4667-f146010897b9edf1-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "d5b75af9-23f4-4f6e-8a8a-714c4baebc9f", - "x-ms-ratelimit-remaining-subscription-writes": "1153", + "x-ms-correlation-request-id": "838406c7-91eb-41d6-8eb6-d05ac74b4494", + "x-ms-ratelimit-remaining-subscription-writes": "1196", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120514Z:d5b75af9-23f4-4f6e-8a8a-714c4baebc9f", - "x-request-time": "0.109" + "x-ms-routing-request-id": "JAPANEAST:20221025T031625Z:838406c7-91eb-41d6-8eb6-d05ac74b4494", + "x-request-time": "0.151" }, "ResponseBody": { "secretsType": "AccountKey", @@ -95,14 +101,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:05:14 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:25 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -112,9 +118,9 @@ "Content-Length": "969", "Content-MD5": "DhunCanKGufSVuPKEYN51w==", "Content-Type": "application/octet-stream", - "Date": "Wed, 12 Oct 2022 12:05:13 GMT", - "ETag": "\u00220x8DAAC46CD3E850B\u0022", - "Last-Modified": "Wed, 12 Oct 2022 11:42:11 GMT", + "Date": "Tue, 25 Oct 2022 03:16:24 GMT", + "ETag": "\u00220x8DA9D83C800EA89\u0022", + "Last-Modified": "Fri, 23 Sep 2022 16:50:54 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -123,10 +129,10 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Wed, 12 Oct 2022 11:42:11 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 16:50:54 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "f2dfb3f1-dd09-4e01-baeb-6fd024a01add", + "x-ms-meta-name": "22f9ea33-2e27-4fad-b979-685cda39afb9", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", @@ -135,20 +141,20 @@ "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:05:14 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:25 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Wed, 12 Oct 2022 12:05:14 GMT", + "Date": "Tue, 25 Oct 2022 03:16:24 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -161,7 +167,7 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -169,7 +175,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -179,31 +185,35 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "822", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:14 GMT", + "Date": "Tue, 25 Oct 2022 03:16:25 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-57c41949ec1096b5622ee03d39fb33c0-c2a54a40623097c4-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-e41d398e072cb0ca723ee323d307158e-2f47757972b47f3e-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "eadf5dc6-3cb4-4106-9cc2-f8c0eb25ad76", - "x-ms-ratelimit-remaining-subscription-writes": "1104", + "x-ms-correlation-request-id": "81c622ed-ac10-416a-bcc2-9ff148f3494a", + "x-ms-ratelimit-remaining-subscription-writes": "1195", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120515Z:eadf5dc6-3cb4-4106-9cc2-f8c0eb25ad76", - "x-request-time": "0.184" + "x-ms-routing-request-id": "JAPANEAST:20221025T031626Z:81c622ed-ac10-416a-bcc2-9ff148f3494a", + "x-request-time": "0.074" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -215,14 +225,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-10-12T11:42:12.3881181\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-09-23T16:50:55.4610694\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-10-12T12:05:14.9472189\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-25T03:16:26.1310264\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -236,7 +246,7 @@ "Connection": "keep-alive", "Content-Length": "897", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -246,7 +256,7 @@ "isArchived": false, "componentSpec": { "command": "python get_data.py --input_data ${{inputs.input_data}} --file_output_data ${{outputs.file_output_data}} --tabular_output_data ${{outputs.tabular_output_data}}", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:5", "name": "azureml_anonymous", "tags": {}, @@ -274,26 +284,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1933", + "Content-Length": "1921", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:16 GMT", + "Date": "Tue, 25 Oct 2022 03:16:26 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-2921cbdb8d9376b3be19ca59100d7538-19412312d5b00475-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-34d70b49a393ba434096f279cfa6f3e8-0066c844af95ded6-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "057eac4f-1f34-42c7-ab21-810959bd7992", - "x-ms-ratelimit-remaining-subscription-writes": "1103", + "x-ms-correlation-request-id": "f41ee9c6-8369-4cca-afae-39f13331e239", + "x-ms-ratelimit-remaining-subscription-writes": "1194", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120516Z:057eac4f-1f34-42c7-ab21-810959bd7992", - "x-request-time": "1.222" + "x-ms-routing-request-id": "JAPANEAST:20221025T031627Z:f41ee9c6-8369-4cca-afae-39f13331e239", + "x-request-time": "0.544" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/4fae7156-16e4-4625-931e-13184542dbeb", - "name": "4fae7156-16e4-4625-931e-13184542dbeb", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/ad4f9b32-5145-4dbf-945f-622cf378c656", + "name": "ad4f9b32-5145-4dbf-945f-622cf378c656", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -303,7 +313,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "4fae7156-16e4-4625-931e-13184542dbeb", + "version": "ad4f9b32-5145-4dbf-945f-622cf378c656", "display_name": "Get_File_Tabular_Dataset", "is_deterministic": "True", "type": "command", @@ -321,8 +331,8 @@ "type": "mltable" } }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", - "environment": "azureml://registries/azureml-dev/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/5", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", + "environment": "azureml://registries/azureml/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/5", "resources": { "instance_count": "1" }, @@ -331,11 +341,11 @@ } }, "systemData": { - "createdAt": "2022-10-12T11:42:14.5797064\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-10-24T09:53:23.946803\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-10-12T11:42:15.057315\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-24T09:53:24.09183\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -347,28 +357,32 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1067", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:17 GMT", + "Date": "Tue, 25 Oct 2022 03:16:27 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-e83287e6f90c9edc12e06fc9627f16a3-63e5c1e63b7889fd-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-06dda8fd1ca48e4e937ed3e912f34b22-3a300db3ee44be0a-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "318ea2fa-7b98-46c2-8eed-e3973cc71720", - "x-ms-ratelimit-remaining-subscription-reads": "11917", + "x-ms-correlation-request-id": "23dd8350-e133-4e5e-92f6-4e9674704bb7", + "x-ms-ratelimit-remaining-subscription-reads": "11989", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120517Z:318ea2fa-7b98-46c2-8eed-e3973cc71720", - "x-request-time": "0.231" + "x-ms-routing-request-id": "JAPANEAST:20221025T031628Z:23dd8350-e133-4e5e-92f6-4e9674704bb7", + "x-request-time": "0.108" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -383,17 +397,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -407,27 +421,29 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "61", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:17 GMT", + "Date": "Tue, 25 Oct 2022 03:16:27 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-0a86b13063abed05253e994661e23d71-04117bb308dfc61b-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-26e6e27a6f10ffd8fec43c2c726cd700-ae1e282f7368ee31-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "f9d3a15d-4922-4302-b2b4-7ed64b80334f", - "x-ms-ratelimit-remaining-subscription-writes": "1152", + "x-ms-correlation-request-id": "ce06c9c1-1c8d-4737-9e20-1ddb88d94d43", + "x-ms-ratelimit-remaining-subscription-writes": "1195", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120518Z:f9d3a15d-4922-4302-b2b4-7ed64b80334f", - "x-request-time": "0.165" + "x-ms-routing-request-id": "JAPANEAST:20221025T031628Z:ce06c9c1-1c8d-4737-9e20-1ddb88d94d43", + "x-request-time": "0.098" }, "ResponseBody": { "secretsType": "AccountKey", @@ -435,14 +451,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:05:18 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:28 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -452,9 +468,9 @@ "Content-Length": "969", "Content-MD5": "DhunCanKGufSVuPKEYN51w==", "Content-Type": "application/octet-stream", - "Date": "Wed, 12 Oct 2022 12:05:18 GMT", - "ETag": "\u00220x8DAAC46CD3E850B\u0022", - "Last-Modified": "Wed, 12 Oct 2022 11:42:11 GMT", + "Date": "Tue, 25 Oct 2022 03:16:28 GMT", + "ETag": "\u00220x8DA9D83C800EA89\u0022", + "Last-Modified": "Fri, 23 Sep 2022 16:50:54 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -463,10 +479,10 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Wed, 12 Oct 2022 11:42:11 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 16:50:54 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "f2dfb3f1-dd09-4e01-baeb-6fd024a01add", + "x-ms-meta-name": "22f9ea33-2e27-4fad-b979-685cda39afb9", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", @@ -475,20 +491,20 @@ "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:05:18 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:28 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Wed, 12 Oct 2022 12:05:18 GMT", + "Date": "Tue, 25 Oct 2022 03:16:28 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -501,7 +517,7 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -509,7 +525,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -519,31 +535,35 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "822", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:18 GMT", + "Date": "Tue, 25 Oct 2022 03:16:28 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-ee2d23c9b524d8ea0bce2bd7212e650a-37613bcf6bba61e6-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-6b43ea7611e2b108cf1577c2257deea2-34e7bf021f2a89e4-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "6cd8bd04-fccc-4680-984c-f1a934fa296a", - "x-ms-ratelimit-remaining-subscription-writes": "1102", + "x-ms-correlation-request-id": "57336ad1-453f-4afb-8518-b9c6d157b386", + "x-ms-ratelimit-remaining-subscription-writes": "1193", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120519Z:6cd8bd04-fccc-4680-984c-f1a934fa296a", - "x-request-time": "0.216" + "x-ms-routing-request-id": "JAPANEAST:20221025T031629Z:57336ad1-453f-4afb-8518-b9c6d157b386", + "x-request-time": "0.066" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -555,14 +575,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-10-12T11:42:12.3881181\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-09-23T16:50:55.4610694\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-10-12T12:05:19.0422993\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-25T03:16:29.5041644\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -576,7 +596,7 @@ "Connection": "keep-alive", "Content-Length": "1217", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -610,7 +630,7 @@ }, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "entry_script": "file_batch_inference.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -626,26 +646,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2224", + "Content-Length": "2214", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:20 GMT", + "Date": "Tue, 25 Oct 2022 03:16:29 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-fa879651bbc0f3d60293c6c86e6023b1-b6540091467bc785-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-d52d39b546a8e7e2f9a716b72db35a8b-ab2d4309284556a7-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "c7041339-7695-44b1-a358-0bdf80583fbb", - "x-ms-ratelimit-remaining-subscription-writes": "1101", + "x-ms-correlation-request-id": "2d55d9cf-5ae2-4a57-8590-c440b00ddcc0", + "x-ms-ratelimit-remaining-subscription-writes": "1192", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120520Z:c7041339-7695-44b1-a358-0bdf80583fbb", - "x-request-time": "1.202" + "x-ms-routing-request-id": "JAPANEAST:20221025T031630Z:2d55d9cf-5ae2-4a57-8590-c440b00ddcc0", + "x-request-time": "0.474" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/3fcb77cd-87db-4c7e-9550-c3bbb06f44c0", - "name": "3fcb77cd-87db-4c7e-9550-c3bbb06f44c0", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/d4792f0a-395b-42a2-9433-c5498e5d9b06", + "name": "d4792f0a-395b-42a2-9433-c5498e5d9b06", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -655,7 +675,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "3fcb77cd-87db-4c7e-9550-c3bbb06f44c0", + "version": "d4792f0a-395b-42a2-9433-c5498e5d9b06", "display_name": "BatchScore", "is_deterministic": "True", "type": "parallel", @@ -673,8 +693,8 @@ } }, "task": { - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", - "environment": "azureml://registries/azureml-dev/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", + "environment": "azureml://registries/azureml/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "entry_script": "file_batch_inference.py", "type": "run_function" @@ -693,11 +713,11 @@ } }, "systemData": { - "createdAt": "2022-10-12T11:42:19.3551047\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-10-24T09:53:28.9487133\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-10-12T11:42:19.8806167\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-24T09:53:29.1452981\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -709,28 +729,32 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1067", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:21 GMT", + "Date": "Tue, 25 Oct 2022 03:16:30 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-7541f4873c45461addadf1f75ac71ba4-fa204db35f37bf4b-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-a9c4a6c63a10fb5954677e02de4fedda-147fcb97e763a016-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "4b7cb438-f1de-4495-8a15-d74e44a20481", - "x-ms-ratelimit-remaining-subscription-reads": "11916", + "x-ms-correlation-request-id": "7e774e02-4695-4bfa-b577-e07b3ea0f127", + "x-ms-ratelimit-remaining-subscription-reads": "11988", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120521Z:4b7cb438-f1de-4495-8a15-d74e44a20481", - "x-request-time": "0.151" + "x-ms-routing-request-id": "JAPANEAST:20221025T031631Z:7e774e02-4695-4bfa-b577-e07b3ea0f127", + "x-request-time": "0.087" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -745,17 +769,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -769,27 +793,29 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "61", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:22 GMT", + "Date": "Tue, 25 Oct 2022 03:16:31 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-434f3d3febf419b7c2d99cf69dfd21c3-d1f43eca5db282e1-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-c3b048952d559568a1d77193d939ab79-4ae7054378c2ade0-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "4993bec5-06dd-4367-bee8-013202c170f4", - "x-ms-ratelimit-remaining-subscription-writes": "1151", + "x-ms-correlation-request-id": "bdccd1df-03e3-4ccc-b8b9-766c41d379b8", + "x-ms-ratelimit-remaining-subscription-writes": "1194", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120522Z:4993bec5-06dd-4367-bee8-013202c170f4", - "x-request-time": "0.095" + "x-ms-routing-request-id": "JAPANEAST:20221025T031631Z:bdccd1df-03e3-4ccc-b8b9-766c41d379b8", + "x-request-time": "0.131" }, "ResponseBody": { "secretsType": "AccountKey", @@ -797,14 +823,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:05:22 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:31 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -814,9 +840,9 @@ "Content-Length": "969", "Content-MD5": "DhunCanKGufSVuPKEYN51w==", "Content-Type": "application/octet-stream", - "Date": "Wed, 12 Oct 2022 12:05:22 GMT", - "ETag": "\u00220x8DAAC46CD3E850B\u0022", - "Last-Modified": "Wed, 12 Oct 2022 11:42:11 GMT", + "Date": "Tue, 25 Oct 2022 03:16:31 GMT", + "ETag": "\u00220x8DA9D83C800EA89\u0022", + "Last-Modified": "Fri, 23 Sep 2022 16:50:54 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -825,10 +851,10 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Wed, 12 Oct 2022 11:42:11 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 16:50:54 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "f2dfb3f1-dd09-4e01-baeb-6fd024a01add", + "x-ms-meta-name": "22f9ea33-2e27-4fad-b979-685cda39afb9", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", @@ -837,20 +863,20 @@ "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:05:23 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:32 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Wed, 12 Oct 2022 12:05:22 GMT", + "Date": "Tue, 25 Oct 2022 03:16:31 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -863,7 +889,7 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -871,7 +897,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -881,31 +907,35 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "822", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:23 GMT", + "Date": "Tue, 25 Oct 2022 03:16:32 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-1c963b4773254383f76d32bb11d7310a-2c3265f69882f015-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-258ef211263a602348bdf3abc583380b-9777293750a51bc7-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "46b857dc-1846-45db-9cd3-fb8689992dbf", - "x-ms-ratelimit-remaining-subscription-writes": "1100", + "x-ms-correlation-request-id": "a8b8039f-c6c2-44c1-aaaf-09b47c0a9f0d", + "x-ms-ratelimit-remaining-subscription-writes": "1191", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120523Z:46b857dc-1846-45db-9cd3-fb8689992dbf", - "x-request-time": "0.186" + "x-ms-routing-request-id": "JAPANEAST:20221025T031632Z:a8b8039f-c6c2-44c1-aaaf-09b47c0a9f0d", + "x-request-time": "0.065" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -917,14 +947,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-10-12T11:42:12.3881181\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-09-23T16:50:55.4610694\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-10-12T12:05:23.6044279\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-25T03:16:32.748079\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -938,7 +968,7 @@ "Connection": "keep-alive", "Content-Length": "809", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -948,7 +978,7 @@ "isArchived": false, "componentSpec": { "command": "python convert_data.py --input_data ${{inputs.input_data}} --file_output_data ${{outputs.file_output_data}}", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:5", "name": "azureml_anonymous", "tags": {}, @@ -973,26 +1003,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1817", + "Content-Length": "1807", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:25 GMT", + "Date": "Tue, 25 Oct 2022 03:16:33 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-f5144374786c18ec04386edd2ba32a34-925f6062c5c1b255-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-db252a09815e0793665dadbb3bf66d99-df0aa03ccd980270-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "03c1afdf-4980-4606-bf10-360fd1707819", - "x-ms-ratelimit-remaining-subscription-writes": "1099", + "x-ms-correlation-request-id": "bc090427-e9dc-408c-8257-ac031065735e", + "x-ms-ratelimit-remaining-subscription-writes": "1190", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120525Z:03c1afdf-4980-4606-bf10-360fd1707819", - "x-request-time": "1.489" + "x-ms-routing-request-id": "JAPANEAST:20221025T031633Z:bc090427-e9dc-408c-8257-ac031065735e", + "x-request-time": "0.511" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/abebd8d5-db53-43d4-9438-04aef2f6a043", - "name": "abebd8d5-db53-43d4-9438-04aef2f6a043", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/bf3bef1e-9b9c-4048-937b-bf768f4e2e5f", + "name": "bf3bef1e-9b9c-4048-937b-bf768f4e2e5f", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -1002,7 +1032,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "abebd8d5-db53-43d4-9438-04aef2f6a043", + "version": "bf3bef1e-9b9c-4048-937b-bf768f4e2e5f", "display_name": "Convert_To_Mltable_File_Dataset", "is_deterministic": "True", "type": "command", @@ -1017,8 +1047,8 @@ "type": "mltable" } }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", - "environment": "azureml://registries/azureml-dev/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/5", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", + "environment": "azureml://registries/azureml/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/5", "resources": { "instance_count": "1" }, @@ -1027,11 +1057,11 @@ } }, "systemData": { - "createdAt": "2022-10-12T11:42:24.2943216\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-10-24T09:53:33.5440815\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-10-12T11:42:24.824946\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-24T09:53:33.710071\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -1043,28 +1073,32 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1067", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:25 GMT", + "Date": "Tue, 25 Oct 2022 03:16:33 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-3a7fc2ffcbe626cb43bdf23947ac4e9c-c280cda63bb4cbdd-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-897c619d27e11909ba5b2eb68b15eab6-dfb1a82a79b280ea-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "d17ebbdb-b0ae-47c3-bc87-a7e35845c562", - "x-ms-ratelimit-remaining-subscription-reads": "11915", + "x-ms-correlation-request-id": "f8e8af6c-c4c0-44b1-8cdf-c6ce8edc61c6", + "x-ms-ratelimit-remaining-subscription-reads": "11987", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120526Z:d17ebbdb-b0ae-47c3-bc87-a7e35845c562", - "x-request-time": "0.148" + "x-ms-routing-request-id": "JAPANEAST:20221025T031634Z:f8e8af6c-c4c0-44b1-8cdf-c6ce8edc61c6", + "x-request-time": "0.121" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -1079,17 +1113,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -1103,27 +1137,29 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "61", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:26 GMT", + "Date": "Tue, 25 Oct 2022 03:16:34 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-55525544e4667911903a418066dbaee3-53ff7ddfaff70649-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-42917c4c7914861507d10486ba67c082-89e4d25fbacaf5b2-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "6e95b3e2-7f51-4524-ae5c-4a01d3e51599", - "x-ms-ratelimit-remaining-subscription-writes": "1150", + "x-ms-correlation-request-id": "a99faec4-ee75-484f-829e-1a395ec62b61", + "x-ms-ratelimit-remaining-subscription-writes": "1193", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120526Z:6e95b3e2-7f51-4524-ae5c-4a01d3e51599", - "x-request-time": "0.094" + "x-ms-routing-request-id": "JAPANEAST:20221025T031635Z:a99faec4-ee75-484f-829e-1a395ec62b61", + "x-request-time": "0.109" }, "ResponseBody": { "secretsType": "AccountKey", @@ -1131,14 +1167,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:05:26 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:35 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -1148,9 +1184,9 @@ "Content-Length": "969", "Content-MD5": "DhunCanKGufSVuPKEYN51w==", "Content-Type": "application/octet-stream", - "Date": "Wed, 12 Oct 2022 12:05:26 GMT", - "ETag": "\u00220x8DAAC46CD3E850B\u0022", - "Last-Modified": "Wed, 12 Oct 2022 11:42:11 GMT", + "Date": "Tue, 25 Oct 2022 03:16:34 GMT", + "ETag": "\u00220x8DA9D83C800EA89\u0022", + "Last-Modified": "Fri, 23 Sep 2022 16:50:54 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -1159,10 +1195,10 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Wed, 12 Oct 2022 11:42:11 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 16:50:54 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "f2dfb3f1-dd09-4e01-baeb-6fd024a01add", + "x-ms-meta-name": "22f9ea33-2e27-4fad-b979-685cda39afb9", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", @@ -1171,20 +1207,20 @@ "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:05:27 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:35 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Wed, 12 Oct 2022 12:05:26 GMT", + "Date": "Tue, 25 Oct 2022 03:16:34 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -1197,7 +1233,7 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -1205,7 +1241,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -1215,31 +1251,35 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "822", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:27 GMT", + "Date": "Tue, 25 Oct 2022 03:16:35 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-5307bac9d15e184da1ee8d57bc530a08-95ae1f2e46fe1323-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-4d43c7dbb67641be1a4e2db71df9b4d2-860b057a4f9cee72-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "637e95a3-6333-4c8f-8c22-c29c8121463f", - "x-ms-ratelimit-remaining-subscription-writes": "1098", + "x-ms-correlation-request-id": "01ea039b-1e50-4d7a-8de3-284dae31a4e5", + "x-ms-ratelimit-remaining-subscription-writes": "1189", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120527Z:637e95a3-6333-4c8f-8c22-c29c8121463f", - "x-request-time": "0.192" + "x-ms-routing-request-id": "JAPANEAST:20221025T031636Z:01ea039b-1e50-4d7a-8de3-284dae31a4e5", + "x-request-time": "0.076" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -1251,14 +1291,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-10-12T11:42:12.3881181\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-09-23T16:50:55.4610694\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-10-12T12:05:27.6961746\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-25T03:16:36.1078521\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -1272,7 +1312,7 @@ "Connection": "keep-alive", "Content-Length": "1217", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -1306,7 +1346,7 @@ }, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "entry_script": "file_batch_inference.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -1322,26 +1362,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2224", + "Content-Length": "2214", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:29 GMT", + "Date": "Tue, 25 Oct 2022 03:16:36 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-7eec4fa2d6d688db8b828e6838f97cd4-cda57a05706bbb9e-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-0fd651c744aac8f3fcbb034610827370-14a98625948efdc5-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "1a46e151-6586-47f4-a49a-6516d1e6a5ee", - "x-ms-ratelimit-remaining-subscription-writes": "1097", + "x-ms-correlation-request-id": "17456d8a-61bb-4cfb-9c6f-1646b318332b", + "x-ms-ratelimit-remaining-subscription-writes": "1188", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120529Z:1a46e151-6586-47f4-a49a-6516d1e6a5ee", - "x-request-time": "1.262" + "x-ms-routing-request-id": "JAPANEAST:20221025T031637Z:17456d8a-61bb-4cfb-9c6f-1646b318332b", + "x-request-time": "0.436" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/3fcb77cd-87db-4c7e-9550-c3bbb06f44c0", - "name": "3fcb77cd-87db-4c7e-9550-c3bbb06f44c0", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/d4792f0a-395b-42a2-9433-c5498e5d9b06", + "name": "d4792f0a-395b-42a2-9433-c5498e5d9b06", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -1351,7 +1391,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "3fcb77cd-87db-4c7e-9550-c3bbb06f44c0", + "version": "d4792f0a-395b-42a2-9433-c5498e5d9b06", "display_name": "BatchScore", "is_deterministic": "True", "type": "parallel", @@ -1369,8 +1409,8 @@ } }, "task": { - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", - "environment": "azureml://registries/azureml-dev/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", + "environment": "azureml://registries/azureml/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "entry_script": "file_batch_inference.py", "type": "run_function" @@ -1389,11 +1429,11 @@ } }, "systemData": { - "createdAt": "2022-10-12T11:42:19.3551047\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-10-24T09:53:28.9487133\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-10-12T11:42:19.8806167\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-24T09:53:29.1452981\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -1405,28 +1445,32 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1067", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:29 GMT", + "Date": "Tue, 25 Oct 2022 03:16:37 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-e42aa3b4dd385d6f59af190015d591fd-fc49b362c841be69-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-577eb9ccf780faee646ca1439b70a153-5078f1a88115ed93-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "8031fa58-06a0-41df-95e6-36a4a0d05141", - "x-ms-ratelimit-remaining-subscription-reads": "11914", + "x-ms-correlation-request-id": "cdbc0de8-0b30-43da-b8aa-0ee255a7de8e", + "x-ms-ratelimit-remaining-subscription-reads": "11986", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120530Z:8031fa58-06a0-41df-95e6-36a4a0d05141", - "x-request-time": "0.116" + "x-ms-routing-request-id": "JAPANEAST:20221025T031637Z:cdbc0de8-0b30-43da-b8aa-0ee255a7de8e", + "x-request-time": "0.086" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -1441,17 +1485,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -1465,27 +1509,29 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "61", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:30 GMT", + "Date": "Tue, 25 Oct 2022 03:16:37 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-41dffa601ba2a3f91dbb45b56b0c963f-649b1dcd7e5de1bd-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-2927cae9beea5632e8f483b2d5c4da2b-f5957a7bcf2dc666-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "2d655f91-e5d2-45f0-aabd-21e22454bada", - "x-ms-ratelimit-remaining-subscription-writes": "1149", + "x-ms-correlation-request-id": "58b103d0-32c9-40de-bf1c-81e126fbd2e3", + "x-ms-ratelimit-remaining-subscription-writes": "1192", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120530Z:2d655f91-e5d2-45f0-aabd-21e22454bada", - "x-request-time": "0.144" + "x-ms-routing-request-id": "JAPANEAST:20221025T031638Z:58b103d0-32c9-40de-bf1c-81e126fbd2e3", + "x-request-time": "0.091" }, "ResponseBody": { "secretsType": "AccountKey", @@ -1493,14 +1539,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:05:30 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:38 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -1510,9 +1556,9 @@ "Content-Length": "969", "Content-MD5": "DhunCanKGufSVuPKEYN51w==", "Content-Type": "application/octet-stream", - "Date": "Wed, 12 Oct 2022 12:05:30 GMT", - "ETag": "\u00220x8DAAC46CD3E850B\u0022", - "Last-Modified": "Wed, 12 Oct 2022 11:42:11 GMT", + "Date": "Tue, 25 Oct 2022 03:16:37 GMT", + "ETag": "\u00220x8DA9D83C800EA89\u0022", + "Last-Modified": "Fri, 23 Sep 2022 16:50:54 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -1521,10 +1567,10 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Wed, 12 Oct 2022 11:42:11 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 16:50:54 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "f2dfb3f1-dd09-4e01-baeb-6fd024a01add", + "x-ms-meta-name": "22f9ea33-2e27-4fad-b979-685cda39afb9", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", @@ -1533,20 +1579,20 @@ "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:05:30 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:38 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Wed, 12 Oct 2022 12:05:30 GMT", + "Date": "Tue, 25 Oct 2022 03:16:38 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -1559,7 +1605,7 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -1567,7 +1613,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -1577,31 +1623,35 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "822", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:34 GMT", + "Date": "Tue, 25 Oct 2022 03:16:38 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-30277ba0c361e8c559c86102fedc5994-0f9ad2384bd07dbb-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-c1340122693d6814289bee8419aea93f-260c627e6d4e8008-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "c50f8056-a87c-4040-8a78-664db9c112a6", - "x-ms-ratelimit-remaining-subscription-writes": "1096", + "x-ms-correlation-request-id": "584fdc11-f72c-4f5f-89d8-fe08e0c96017", + "x-ms-ratelimit-remaining-subscription-writes": "1187", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120535Z:c50f8056-a87c-4040-8a78-664db9c112a6", - "x-request-time": "0.192" + "x-ms-routing-request-id": "JAPANEAST:20221025T031639Z:584fdc11-f72c-4f5f-89d8-fe08e0c96017", + "x-request-time": "0.063" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -1613,14 +1663,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-10-12T11:42:12.3881181\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-09-23T16:50:55.4610694\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-10-12T12:05:35.3283474\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-25T03:16:39.4949139\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -1634,7 +1684,7 @@ "Connection": "keep-alive", "Content-Length": "416", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -1646,24 +1696,24 @@ }, "StatusCode": 201, "ResponseHeaders": { - "Build-ID": "cap", + "Build-ID": "chj", "Cache-Control": "no-cache", - "Content-Length": "1351", + "Content-Length": "1359", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:36 GMT", + "Date": "Tue, 25 Oct 2022 03:16:39 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-31c9a9300cecd2b394bee45c5a45cf36-8ec4b7ee7d4893ec-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-3c1b1e942e77bef46b98a70a0596a4ff-f564665867abe6e7-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "687c4068-efd0-4c01-b555-670e665fe6a4", - "x-ms-ratelimit-remaining-subscription-writes": "1095", + "x-ms-correlation-request-id": "1178067e-593d-48dc-9321-dd2207c9beba", + "x-ms-ratelimit-remaining-subscription-writes": "1186", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120536Z:687c4068-efd0-4c01-b555-670e665fe6a4", - "x-request-time": "0.745" + "x-ms-routing-request-id": "JAPANEAST:20221025T031640Z:1178067e-593d-48dc-9321-dd2207c9beba", + "x-request-time": "0.426" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af", @@ -1681,11 +1731,11 @@ "osType": "Linux" }, "systemData": { - "createdAt": "2022-09-23T09:56:46.9554352\u002B00:00", - "createdBy": "Ying Chen", + "createdAt": "2022-09-23T15:25:10.3353821\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-09-23T09:56:46.9554352\u002B00:00", - "lastModifiedBy": "Ying Chen", + "lastModifiedAt": "2022-09-23T15:25:10.3353821\u002B00:00", + "lastModifiedBy": "Zhengfei Wang", "lastModifiedByType": "User" } } @@ -1699,7 +1749,7 @@ "Connection": "keep-alive", "Content-Length": "1543", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -1735,7 +1785,7 @@ "logging_level": "DEBUG", "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "entry_script": "tabular_batch_inference.py", "program_arguments": "--model ${{inputs.score_model}}", "append_row_to": "${{outputs.job_out_path}}", @@ -1758,24 +1808,24 @@ "Cache-Control": "no-cache", "Content-Length": "2538", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:37 GMT", + "Date": "Tue, 25 Oct 2022 03:16:40 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-d6d883570170c2e799ca0bb520850315-b807dd7204c0d71c-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-e740da3011ef3cbb6e9e3dbb65630138-e8cda2673f298e39-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "fbb0c05b-7d20-4121-bcee-bba3516a01bf", - "x-ms-ratelimit-remaining-subscription-writes": "1094", + "x-ms-correlation-request-id": "e4b7efcc-308f-4207-817c-a34a11dc1971", + "x-ms-ratelimit-remaining-subscription-writes": "1185", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120537Z:fbb0c05b-7d20-4121-bcee-bba3516a01bf", - "x-request-time": "0.551" + "x-ms-routing-request-id": "JAPANEAST:20221025T031641Z:e4b7efcc-308f-4207-817c-a34a11dc1971", + "x-request-time": "0.429" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/565ac135-8334-45bf-8dfd-62daf6f286ac", - "name": "565ac135-8334-45bf-8dfd-62daf6f286ac", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/be97b918-a8d9-4188-abfa-448f8d123e91", + "name": "be97b918-a8d9-4188-abfa-448f8d123e91", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -1785,7 +1835,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "565ac135-8334-45bf-8dfd-62daf6f286ac", + "version": "be97b918-a8d9-4188-abfa-448f8d123e91", "display_name": "BatchScore", "is_deterministic": "True", "type": "parallel", @@ -1808,7 +1858,7 @@ } }, "task": { - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "environment": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af", "program_arguments": "--model ${{inputs.score_model}}", "entry_script": "tabular_batch_inference.py", @@ -1829,11 +1879,11 @@ } }, "systemData": { - "createdAt": "2022-10-12T11:42:33.5404463\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-09-23T16:51:37.9797646\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-10-12T11:42:34.0369268\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-09-23T16:51:38.1913953\u002B00:00", + "lastModifiedBy": "Zhengfei Wang", "lastModifiedByType": "User" } } @@ -1845,28 +1895,32 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1067", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:37 GMT", + "Date": "Tue, 25 Oct 2022 03:16:41 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-21d6a1f9636b3052df020f312e2d95c6-717092ac881b0bfa-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-bf109038b5dfe9c7843390493c1dfc3a-6905a829063b5378-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "e945053d-f4b5-4b4a-88df-c6ca0566fbb2", - "x-ms-ratelimit-remaining-subscription-reads": "11913", + "x-ms-correlation-request-id": "1eb15633-3006-450a-8c8a-6d288d49592b", + "x-ms-ratelimit-remaining-subscription-reads": "11985", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120538Z:e945053d-f4b5-4b4a-88df-c6ca0566fbb2", - "x-request-time": "0.112" + "x-ms-routing-request-id": "JAPANEAST:20221025T031642Z:1eb15633-3006-450a-8c8a-6d288d49592b", + "x-request-time": "0.092" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -1881,17 +1935,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -1905,27 +1959,29 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "61", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:38 GMT", + "Date": "Tue, 25 Oct 2022 03:16:41 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-c130756fe94345e3d7c958a7cbe49ecc-b737f511b152e4e0-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-099716ba2ecd524b461cac48c7a877d9-b271a3474a0883e4-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "b8826efb-29ee-4863-b709-ff5256793326", - "x-ms-ratelimit-remaining-subscription-writes": "1148", + "x-ms-correlation-request-id": "6c0aac9f-5835-4a23-8af4-7a960863317e", + "x-ms-ratelimit-remaining-subscription-writes": "1191", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120539Z:b8826efb-29ee-4863-b709-ff5256793326", - "x-request-time": "0.242" + "x-ms-routing-request-id": "JAPANEAST:20221025T031642Z:6c0aac9f-5835-4a23-8af4-7a960863317e", + "x-request-time": "0.095" }, "ResponseBody": { "secretsType": "AccountKey", @@ -1933,14 +1989,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/dataset/iris-mltable/MLTable", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/dataset/iris-mltable/MLTable", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:05:39 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:42 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -1950,9 +2006,9 @@ "Content-Length": "152", "Content-MD5": "LPwZTVvE9cmq2xCV9B8RmQ==", "Content-Type": "application/octet-stream", - "Date": "Wed, 12 Oct 2022 12:05:39 GMT", - "ETag": "\u00220x8DAAC46DC5BEBB0\u0022", - "Last-Modified": "Wed, 12 Oct 2022 11:42:37 GMT", + "Date": "Tue, 25 Oct 2022 03:16:42 GMT", + "ETag": "\u00220x8DA9D83E74663EE\u0022", + "Last-Modified": "Fri, 23 Sep 2022 16:51:47 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -1961,32 +2017,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Wed, 12 Oct 2022 11:42:35 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 16:51:44 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "9363c2f4-598d-45ef-aaf5-d0d9c9676d86", + "x-ms-meta-name": "bdc85477-b262-4a27-8153-5ebcf73182d1", "x-ms-meta-upload_status": "completed", - "x-ms-meta-version": "786f170d-cf16-4f22-b115-05be3818209e", + "x-ms-meta-version": "6becb243-4444-4902-b571-a3587f2b5f87", "x-ms-server-encrypted": "true", "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/dataset/iris-mltable/MLTable", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/dataset/iris-mltable/MLTable", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:05:39 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:42 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Wed, 12 Oct 2022 12:05:51 GMT", + "Date": "Tue, 25 Oct 2022 03:16:42 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -2005,28 +2061,32 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1067", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:51 GMT", + "Date": "Tue, 25 Oct 2022 03:16:43 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-5eb6a0d8944bdcc1ebae2d7647560912-c194307868098545-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-4f4cd165ad606bf1c2913bb94eaedeb3-2f37d0ecf5cf9c2b-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "54d5325a-be36-4d07-b3f9-cb70a63a515f", - "x-ms-ratelimit-remaining-subscription-reads": "11912", + "x-ms-correlation-request-id": "1fea90d7-c2db-4f98-8418-c2cb635e100a", + "x-ms-ratelimit-remaining-subscription-reads": "11984", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120552Z:54d5325a-be36-4d07-b3f9-cb70a63a515f", - "x-request-time": "0.117" + "x-ms-routing-request-id": "JAPANEAST:20221025T031643Z:1fea90d7-c2db-4f98-8418-c2cb635e100a", + "x-request-time": "0.111" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -2041,17 +2101,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -2065,27 +2125,29 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "61", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:51 GMT", + "Date": "Tue, 25 Oct 2022 03:16:43 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-05f1b13e779636d7412dc5985f8642c7-4f32ced4e5032552-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-b804d0797676c019e7c71bef0b0ae86d-84fa3fce120a810a-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "e89d4bc4-48c9-4a20-81a8-43ebecdfc957", - "x-ms-ratelimit-remaining-subscription-writes": "1147", + "x-ms-correlation-request-id": "71cdd71c-fc8c-4174-abd3-bd38745a5dea", + "x-ms-ratelimit-remaining-subscription-writes": "1190", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120552Z:e89d4bc4-48c9-4a20-81a8-43ebecdfc957", - "x-request-time": "0.088" + "x-ms-routing-request-id": "JAPANEAST:20221025T031644Z:71cdd71c-fc8c-4174-abd3-bd38745a5dea", + "x-request-time": "0.093" }, "ResponseBody": { "secretsType": "AccountKey", @@ -2093,14 +2155,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/model/iris_model/MLmodel", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/model/iris_model/MLmodel", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:05:52 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:44 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -2110,9 +2172,9 @@ "Content-Length": "298", "Content-MD5": "HaKpUL6X1WimkPVJF2lHiQ==", "Content-Type": "application/octet-stream", - "Date": "Wed, 12 Oct 2022 12:05:52 GMT", - "ETag": "\u00220x8DA9F724DE7D1C0\u0022", - "Last-Modified": "Mon, 26 Sep 2022 03:50:50 GMT", + "Date": "Tue, 25 Oct 2022 03:16:43 GMT", + "ETag": "\u00220x8DA9D83BBE50DC7\u0022", + "Last-Modified": "Fri, 23 Sep 2022 16:50:34 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -2121,32 +2183,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 26 Sep 2022 03:50:50 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 16:50:34 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "51476e36-8cf8-416d-bf8b-25916df42b46", + "x-ms-meta-name": "0244b266-812d-4fb7-80cb-3a1864deca7d", "x-ms-meta-upload_status": "completed", - "x-ms-meta-version": "0a84439e-8a55-4b45-b30c-152bf4c097e6", + "x-ms-meta-version": "b3692c50-6ae9-4d6d-8457-16f9224f5e86", "x-ms-server-encrypted": "true", "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/model/iris_model/MLmodel", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/model/iris_model/MLmodel", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:05:52 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:44 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Wed, 12 Oct 2022 12:05:52 GMT", + "Date": "Tue, 25 Oct 2022 03:16:44 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -2165,9 +2227,9 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "6645", + "Content-Length": "6717", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -2216,7 +2278,7 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/4fae7156-16e4-4625-931e-13184542dbeb" + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/ad4f9b32-5145-4dbf-945f-622cf378c656" }, "file_batch_inference_node": { "type": "parallel", @@ -2230,7 +2292,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "entry_script": "file_batch_inference.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -2250,10 +2312,11 @@ "outputs": {}, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/3fcb77cd-87db-4c7e-9550-c3bbb06f44c0", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/d4792f0a-395b-42a2-9433-c5498e5d9b06", "retry_settings": null, "logging_level": "DEBUG", - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null }, "convert_data_node": { "resources": null, @@ -2278,7 +2341,7 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/abebd8d5-db53-43d4-9438-04aef2f6a043" + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/bf3bef1e-9b9c-4048-937b-bf768f4e2e5f" }, "file_batch_inference_duplicate_node": { "type": "parallel", @@ -2292,7 +2355,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "entry_script": "file_batch_inference.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -2317,10 +2380,11 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/3fcb77cd-87db-4c7e-9550-c3bbb06f44c0", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/d4792f0a-395b-42a2-9433-c5498e5d9b06", "retry_settings": null, "logging_level": "DEBUG", - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null }, "tabular_batch_inference_node": { "type": "parallel", @@ -2331,7 +2395,7 @@ "max_concurrency_per_instance": 2, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "entry_script": "tabular_batch_inference.py", "program_arguments": "--model ${{inputs.score_model}}", "append_row_to": "${{outputs.job_out_path}}", @@ -2361,10 +2425,11 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/565ac135-8334-45bf-8dfd-62daf6f286ac", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/be97b918-a8d9-4188-abfa-448f8d123e91", "retry_settings": null, "logging_level": "DEBUG", - "mini_batch_size": 100 + "mini_batch_size": 100, + "partition_keys": null } }, "outputs": { @@ -2385,22 +2450,22 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "10439", + "Content-Length": "10528", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:59 GMT", + "Date": "Tue, 25 Oct 2022 03:16:53 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-765f5dac81346e56d7240fdce8b4e44d-ff51daffa2dc2451-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-a21dd6b7ee77d3884ef2a622b2c9ac9f-a096788741fe0960-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "b873355e-6e83-4ac9-8d27-289d6c9c9b46", - "x-ms-ratelimit-remaining-subscription-writes": "1093", + "x-ms-correlation-request-id": "016ad746-c3b0-498a-b309-cf9610329ea9", + "x-ms-ratelimit-remaining-subscription-writes": "1184", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120600Z:b873355e-6e83-4ac9-8d27-289d6c9c9b46", - "x-request-time": "3.702" + "x-ms-routing-request-id": "JAPANEAST:20221025T031654Z:016ad746-c3b0-498a-b309-cf9610329ea9", + "x-request-time": "4.945" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000", @@ -2428,7 +2493,7 @@ "Tracking": { "jobServiceType": "Tracking", "port": null, - "endpoint": "azureml://master.api.azureml-test.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", + "endpoint": "azureml://eastus2.api.azureml.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", "status": null, "errorMessage": null, "properties": null, @@ -2480,7 +2545,7 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/4fae7156-16e4-4625-931e-13184542dbeb" + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/ad4f9b32-5145-4dbf-945f-622cf378c656" }, "file_batch_inference_node": { "type": "parallel", @@ -2494,7 +2559,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "entry_script": "file_batch_inference.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -2514,10 +2579,11 @@ "outputs": {}, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/3fcb77cd-87db-4c7e-9550-c3bbb06f44c0", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/d4792f0a-395b-42a2-9433-c5498e5d9b06", "retry_settings": null, "logging_level": "DEBUG", - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null }, "convert_data_node": { "resources": null, @@ -2542,7 +2608,7 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/abebd8d5-db53-43d4-9438-04aef2f6a043" + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/bf3bef1e-9b9c-4048-937b-bf768f4e2e5f" }, "file_batch_inference_duplicate_node": { "type": "parallel", @@ -2556,7 +2622,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "entry_script": "file_batch_inference.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -2581,10 +2647,11 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/3fcb77cd-87db-4c7e-9550-c3bbb06f44c0", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/d4792f0a-395b-42a2-9433-c5498e5d9b06", "retry_settings": null, "logging_level": "DEBUG", - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null }, "tabular_batch_inference_node": { "type": "parallel", @@ -2595,7 +2662,7 @@ "max_concurrency_per_instance": 2, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/f2dfb3f1-dd09-4e01-baeb-6fd024a01add/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/22f9ea33-2e27-4fad-b979-685cda39afb9/versions/1", "entry_script": "tabular_batch_inference.py", "program_arguments": "--model ${{inputs.score_model}}", "append_row_to": "${{outputs.job_out_path}}", @@ -2625,10 +2692,11 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/565ac135-8334-45bf-8dfd-62daf6f286ac", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/be97b918-a8d9-4188-abfa-448f8d123e91", "retry_settings": null, "logging_level": "DEBUG", - "mini_batch_size": 100 + "mini_batch_size": 100, + "partition_keys": null } }, "inputs": { @@ -2662,8 +2730,8 @@ "sourceJobId": null }, "systemData": { - "createdAt": "2022-10-12T12:05:59.8689038\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-10-25T03:16:53.9509972\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline_samples.pyTestDSLPipelineSamplestest_parallel_components_with_tabular_input_pipeline_output.json b/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline_samples.pyTestDSLPipelineSamplestest_parallel_components_with_tabular_input_pipeline_output.json index 328fc8616081..1f1b90aba80b 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline_samples.pyTestDSLPipelineSamplestest_parallel_components_with_tabular_input_pipeline_output.json +++ b/sdk/ml/azure-ai-ml/tests/recordings/dsl/e2etests/test_dsl_pipeline_samples.pyTestDSLPipelineSamplestest_parallel_components_with_tabular_input_pipeline_output.json @@ -7,43 +7,47 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1512", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:38 GMT", + "Date": "Tue, 25 Oct 2022 03:15:55 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-8802c5cc0a29a1a4e7d9d3463a1611a3-80953750fb88229d-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-a98d22f9f474b3986916aafc93bf52b4-2bc4b93494cd2417-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "532cf9a6-085c-46f5-b7ae-8947d487d4cb", - "x-ms-ratelimit-remaining-subscription-reads": "11922", + "x-ms-correlation-request-id": "c2370fa2-5725-484e-8b99-60aa6f5942dd", + "x-ms-ratelimit-remaining-subscription-reads": "11995", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120438Z:532cf9a6-085c-46f5-b7ae-8947d487d4cb", - "x-request-time": "0.230" + "x-ms-routing-request-id": "JAPANEAST:20221025T031556Z:c2370fa2-5725-484e-8b99-60aa6f5942dd", + "x-request-time": "0.037" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", "name": "cpu-cluster", "type": "Microsoft.MachineLearningServices/workspaces/computes", - "location": "centraluseuap", + "location": "eastus2", "tags": {}, "properties": { - "createdOn": "2022-09-22T09:02:22.1899959\u002B00:00", - "modifiedOn": "2022-09-23T03:28:18.0066218\u002B00:00", + "createdOn": "2022-09-22T03:07:49.0785672\u002B00:00", + "modifiedOn": "2022-10-11T04:29:30.5828273\u002B00:00", "disableLocalAuth": false, "description": null, "resourceId": null, "computeType": "AmlCompute", - "computeLocation": "centraluseuap", + "computeLocation": "eastus2", "provisioningState": "Succeeded", "provisioningErrors": null, "isAttachedCompute": false, @@ -52,22 +56,22 @@ "vmPriority": "Dedicated", "scaleSettings": { "maxNodeCount": 4, - "minNodeCount": 1, + "minNodeCount": 0, "nodeIdleTimeBeforeScaleDown": "PT2M" }, "subnet": null, - "currentNodeCount": 1, + "currentNodeCount": 0, "targetNodeCount": 1, "nodeStateCounts": { "preparingNodeCount": 0, "runningNodeCount": 0, - "idleNodeCount": 1, + "idleNodeCount": 0, "unusableNodeCount": 0, "leavingNodeCount": 0, "preemptedNodeCount": 0 }, - "allocationState": "Steady", - "allocationStateTransitionTime": "2022-09-30T08:08:43.647\u002B00:00", + "allocationState": "Resizing", + "allocationStateTransitionTime": "2022-10-25T03:14:52.58\u002B00:00", "errors": null, "remoteLoginPortPublicAccess": "Enabled", "osType": "Linux", @@ -85,28 +89,32 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1067", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:41 GMT", + "Date": "Tue, 25 Oct 2022 03:15:59 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-760a42aa0d726fa0771114538bd3a4f9-71140026a871ba39-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-0297911f02b0eaa0856adbaf7f60645f-064253509a2d4617-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "44634c53-62f4-49fb-9dde-69df8c9976b5", - "x-ms-ratelimit-remaining-subscription-reads": "11921", + "x-ms-correlation-request-id": "d8d6aa89-2554-42d6-ba47-5fd2df663fb5", + "x-ms-ratelimit-remaining-subscription-reads": "11994", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120441Z:44634c53-62f4-49fb-9dde-69df8c9976b5", - "x-request-time": "0.258" + "x-ms-routing-request-id": "JAPANEAST:20221025T031559Z:d8d6aa89-2554-42d6-ba47-5fd2df663fb5", + "x-request-time": "0.087" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -121,17 +129,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -145,27 +153,29 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "61", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:41 GMT", + "Date": "Tue, 25 Oct 2022 03:16:00 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-d665f6a739b7e385cc76f1e07ac3a692-7fbe6456e200f0b4-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-73aaef16e5affe6b783affc1e08f7ed0-05b5a414ee018cde-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "90b71d55-9f75-4bae-a7de-b7f8097bc88e", - "x-ms-ratelimit-remaining-subscription-writes": "1156", + "x-ms-correlation-request-id": "72c07ebf-e8cb-40a5-b409-30c3b53fd1d3", + "x-ms-ratelimit-remaining-subscription-writes": "1199", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120442Z:90b71d55-9f75-4bae-a7de-b7f8097bc88e", - "x-request-time": "0.092" + "x-ms-routing-request-id": "JAPANEAST:20221025T031600Z:72c07ebf-e8cb-40a5-b409-30c3b53fd1d3", + "x-request-time": "0.231" }, "ResponseBody": { "secretsType": "AccountKey", @@ -173,14 +183,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src/tabular_run_with_model.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/tabular_run_with_model.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:04:42 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:00 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -190,9 +200,9 @@ "Content-Length": "1102", "Content-MD5": "jO1FYErTQcHautv7oG0/KQ==", "Content-Type": "application/octet-stream", - "Date": "Wed, 12 Oct 2022 12:04:41 GMT", - "ETag": "\u00220x8DA9F723EC4C5DE\u0022", - "Last-Modified": "Mon, 26 Sep 2022 03:50:25 GMT", + "Date": "Tue, 25 Oct 2022 03:16:00 GMT", + "ETag": "\u00220x8DA9D805F140855\u0022", + "Last-Modified": "Fri, 23 Sep 2022 16:26:30 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -201,10 +211,10 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 26 Sep 2022 03:50:25 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 16:26:29 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "db5e7941-8b47-4a43-b6ff-7c9d765449c5", + "x-ms-meta-name": "47ddf675-0155-4289-96eb-c37908b696c0", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", @@ -213,20 +223,20 @@ "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/src/tabular_run_with_model.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/tabular_run_with_model.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:04:42 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:01 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Wed, 12 Oct 2022 12:04:42 GMT", + "Date": "Tue, 25 Oct 2022 03:16:01 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -239,7 +249,7 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/db5e7941-8b47-4a43-b6ff-7c9d765449c5/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/47ddf675-0155-4289-96eb-c37908b696c0/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -247,7 +257,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -257,31 +267,35 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "822", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:43 GMT", + "Date": "Tue, 25 Oct 2022 03:16:02 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-a6e996b7e2d436f9b48321cf2b117ebd-0550c8f3df304ba5-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-5755a58569d2fefa7866a6e96e21a552-114bde61079aeb74-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "6eea84c7-ae29-4b37-8684-9e433ed327ba", - "x-ms-ratelimit-remaining-subscription-writes": "1108", + "x-ms-correlation-request-id": "59030cfa-d33a-49dc-aabd-db35834567b3", + "x-ms-ratelimit-remaining-subscription-writes": "1199", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120443Z:6eea84c7-ae29-4b37-8684-9e433ed327ba", - "x-request-time": "0.231" + "x-ms-routing-request-id": "JAPANEAST:20221025T031603Z:59030cfa-d33a-49dc-aabd-db35834567b3", + "x-request-time": "0.117" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/db5e7941-8b47-4a43-b6ff-7c9d765449c5/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/47ddf675-0155-4289-96eb-c37908b696c0/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -293,14 +307,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-09-26T03:50:27.0266351\u002B00:00", + "createdAt": "2022-09-23T16:26:31.1781796\u002B00:00", "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-10-12T12:04:42.9822748\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-25T03:16:03.0231571\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -314,7 +328,7 @@ "Connection": "keep-alive", "Content-Length": "416", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -326,24 +340,24 @@ }, "StatusCode": 201, "ResponseHeaders": { - "Build-ID": "cap", + "Build-ID": "chj", "Cache-Control": "no-cache", - "Content-Length": "1351", + "Content-Length": "1359", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:56 GMT", + "Date": "Tue, 25 Oct 2022 03:16:03 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-52dbd7fffb0e71f278a35f0f63d9a855-6f306ff0df2391c1-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-24490e291486dbda46da836b0447bb18-322b859bae726431-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "9e2bc06f-50fa-4543-9b85-3cac67394eb7", - "x-ms-ratelimit-remaining-subscription-writes": "1107", + "x-ms-correlation-request-id": "9738ef73-0ecc-4ad5-8003-262ac681c3c5", + "x-ms-ratelimit-remaining-subscription-writes": "1198", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120456Z:9e2bc06f-50fa-4543-9b85-3cac67394eb7", - "x-request-time": "12.560" + "x-ms-routing-request-id": "JAPANEAST:20221025T031604Z:9738ef73-0ecc-4ad5-8003-262ac681c3c5", + "x-request-time": "0.470" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af", @@ -361,11 +375,11 @@ "osType": "Linux" }, "systemData": { - "createdAt": "2022-09-23T09:56:46.9554352\u002B00:00", - "createdBy": "Ying Chen", + "createdAt": "2022-09-23T15:25:10.3353821\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-09-23T09:56:46.9554352\u002B00:00", - "lastModifiedBy": "Ying Chen", + "lastModifiedAt": "2022-09-23T15:25:10.3353821\u002B00:00", + "lastModifiedBy": "Zhengfei Wang", "lastModifiedByType": "User" } } @@ -379,7 +393,7 @@ "Connection": "keep-alive", "Content-Length": "1542", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -415,7 +429,7 @@ "logging_level": "DEBUG", "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/db5e7941-8b47-4a43-b6ff-7c9d765449c5/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/47ddf675-0155-4289-96eb-c37908b696c0/versions/1", "entry_script": "tabular_run_with_model.py", "program_arguments": "--model ${{inputs.score_model}}", "append_row_to": "${{outputs.job_out_path}}", @@ -438,24 +452,24 @@ "Cache-Control": "no-cache", "Content-Length": "2536", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:57 GMT", + "Date": "Tue, 25 Oct 2022 03:16:04 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-2c514a34bc9757231c01595e900d03b9-646dca2d2bd30800-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-8d1ff28cb6a82bc07f50a277ebe2d8ad-2bd28e60ce9d0c41-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "3d7348ba-f1cd-4e17-904b-2cf420b2dea8", - "x-ms-ratelimit-remaining-subscription-writes": "1106", + "x-ms-correlation-request-id": "242c5185-9599-4b6c-86fc-3e8bb67b9328", + "x-ms-ratelimit-remaining-subscription-writes": "1197", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120457Z:3d7348ba-f1cd-4e17-904b-2cf420b2dea8", - "x-request-time": "0.561" + "x-ms-routing-request-id": "JAPANEAST:20221025T031605Z:242c5185-9599-4b6c-86fc-3e8bb67b9328", + "x-request-time": "0.476" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/53651e6f-94ce-4a84-a639-f24a49915b45", - "name": "53651e6f-94ce-4a84-a639-f24a49915b45", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/234be6de-944e-4498-bdf4-e89058b5f16c", + "name": "234be6de-944e-4498-bdf4-e89058b5f16c", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -465,7 +479,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "53651e6f-94ce-4a84-a639-f24a49915b45", + "version": "234be6de-944e-4498-bdf4-e89058b5f16c", "display_name": "BatchScore", "is_deterministic": "True", "type": "parallel", @@ -488,7 +502,7 @@ } }, "task": { - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/db5e7941-8b47-4a43-b6ff-7c9d765449c5/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/47ddf675-0155-4289-96eb-c37908b696c0/versions/1", "environment": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af", "program_arguments": "--model ${{inputs.score_model}}", "entry_script": "tabular_run_with_model.py", @@ -509,10 +523,10 @@ } }, "systemData": { - "createdAt": "2022-09-26T03:50:45.073385\u002B00:00", + "createdAt": "2022-09-23T16:26:48.5666167\u002B00:00", "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-09-26T03:50:45.6149135\u002B00:00", + "lastModifiedAt": "2022-09-23T16:26:48.762222\u002B00:00", "lastModifiedBy": "Zhengfei Wang", "lastModifiedByType": "User" } @@ -525,28 +539,32 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1067", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:57 GMT", + "Date": "Tue, 25 Oct 2022 03:16:05 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-a23b4a35975eb92abd003d4aa9cb6ce2-1aeaa80b216a9b27-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-be7646b45eb8da3d381884ec0573c7b6-6388108ebdc62104-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "5c397878-f4ec-45a3-861c-056cc57377d5", - "x-ms-ratelimit-remaining-subscription-reads": "11920", + "x-ms-correlation-request-id": "f71787ab-8e47-45ce-a964-491d522bd106", + "x-ms-ratelimit-remaining-subscription-reads": "11992", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120458Z:5c397878-f4ec-45a3-861c-056cc57377d5", - "x-request-time": "0.156" + "x-ms-routing-request-id": "JAPANEAST:20221025T031605Z:f71787ab-8e47-45ce-a964-491d522bd106", + "x-request-time": "0.093" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -561,17 +579,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -585,27 +603,29 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "61", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:58 GMT", + "Date": "Tue, 25 Oct 2022 03:16:06 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-1336814d1cb38db771b56b9592b6df35-9259f950a3103dae-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-e3f23ae5f563d69d8212894a86c31d84-66340fcdc2c44131-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "dffc7f26-9440-4fe5-a9df-c7cb94ba7336", - "x-ms-ratelimit-remaining-subscription-writes": "1155", + "x-ms-correlation-request-id": "2fcf0623-68f4-4d05-b427-7eb2d559eed0", + "x-ms-ratelimit-remaining-subscription-writes": "1198", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120458Z:dffc7f26-9440-4fe5-a9df-c7cb94ba7336", - "x-request-time": "0.551" + "x-ms-routing-request-id": "JAPANEAST:20221025T031606Z:2fcf0623-68f4-4d05-b427-7eb2d559eed0", + "x-request-time": "0.095" }, "ResponseBody": { "secretsType": "AccountKey", @@ -613,14 +633,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/iris-mltable/MLTable", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/iris-mltable/MLTable", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:04:59 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:06 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -630,9 +650,9 @@ "Content-Length": "152", "Content-MD5": "LPwZTVvE9cmq2xCV9B8RmQ==", "Content-Type": "application/octet-stream", - "Date": "Wed, 12 Oct 2022 12:04:58 GMT", - "ETag": "\u00220x8DA9F724C7453D2\u0022", - "Last-Modified": "Mon, 26 Sep 2022 03:50:48 GMT", + "Date": "Tue, 25 Oct 2022 03:16:06 GMT", + "ETag": "\u00220x8DA9D83B81DBF77\u0022", + "Last-Modified": "Fri, 23 Sep 2022 16:50:28 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -641,32 +661,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 26 Sep 2022 03:50:47 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 16:50:26 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "aa08403b-a5bb-440c-a08c-bbf2b273d6f3", + "x-ms-meta-name": "e36d374f-0816-4efb-888d-00c727ccdf78", "x-ms-meta-upload_status": "completed", - "x-ms-meta-version": "921fbdcc-8251-498a-975c-dbfd10345ab8", + "x-ms-meta-version": "b6c1b02b-ff69-4fd9-b5ef-575602cc7ca8", "x-ms-server-encrypted": "true", "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/iris-mltable/MLTable", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/iris-mltable/MLTable", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:04:59 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:06 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Wed, 12 Oct 2022 12:04:59 GMT", + "Date": "Tue, 25 Oct 2022 03:16:06 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -685,28 +705,32 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1067", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:04:59 GMT", + "Date": "Tue, 25 Oct 2022 03:16:07 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-6787c073810c634d37da6165a3ea768b-3320a2e54272aba3-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-003b5a553bf60a11203cbafdb987b7c1-e0050e6492b6d5d0-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": [ + "Accept-Encoding", + "Accept-Encoding" + ], + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "adb915a3-f395-405c-bc4a-3244c0351ea8", - "x-ms-ratelimit-remaining-subscription-reads": "11919", + "x-ms-correlation-request-id": "a21f8119-55a6-46c4-be00-2d7abc4b92b2", + "x-ms-ratelimit-remaining-subscription-reads": "11991", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120459Z:adb915a3-f395-405c-bc4a-3244c0351ea8", - "x-request-time": "0.136" + "x-ms-routing-request-id": "JAPANEAST:20221025T031607Z:a21f8119-55a6-46c4-be00-2d7abc4b92b2", + "x-request-time": "0.074" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -721,17 +745,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -745,27 +769,29 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "61", + "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:00 GMT", + "Date": "Tue, 25 Oct 2022 03:16:08 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-510ca15ca591a4eaebb6d5d4cb8d8b54-be5d5e6a9fe7c2b1-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-c9baa942d04ef1b9a9a988e6a678a6c1-730d69c9bba66b27-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "Transfer-Encoding": "chunked", + "Vary": "Accept-Encoding", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "5454e78a-f1cc-4db8-b56f-dcb6684cc78b", - "x-ms-ratelimit-remaining-subscription-writes": "1154", + "x-ms-correlation-request-id": "aecb950c-3a15-4b09-8645-926476a5db45", + "x-ms-ratelimit-remaining-subscription-writes": "1197", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120500Z:5454e78a-f1cc-4db8-b56f-dcb6684cc78b", - "x-request-time": "0.092" + "x-ms-routing-request-id": "JAPANEAST:20221025T031608Z:aecb950c-3a15-4b09-8645-926476a5db45", + "x-request-time": "0.110" }, "ResponseBody": { "secretsType": "AccountKey", @@ -773,14 +799,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/model/iris_model/MLmodel", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/model/iris_model/MLmodel", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:05:00 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:08 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -790,9 +816,9 @@ "Content-Length": "298", "Content-MD5": "HaKpUL6X1WimkPVJF2lHiQ==", "Content-Type": "application/octet-stream", - "Date": "Wed, 12 Oct 2022 12:05:00 GMT", - "ETag": "\u00220x8DA9F724DE7D1C0\u0022", - "Last-Modified": "Mon, 26 Sep 2022 03:50:50 GMT", + "Date": "Tue, 25 Oct 2022 03:16:07 GMT", + "ETag": "\u00220x8DA9D83BBE50DC7\u0022", + "Last-Modified": "Fri, 23 Sep 2022 16:50:34 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -801,32 +827,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 26 Sep 2022 03:50:50 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 16:50:34 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "51476e36-8cf8-416d-bf8b-25916df42b46", + "x-ms-meta-name": "0244b266-812d-4fb7-80cb-3a1864deca7d", "x-ms-meta-upload_status": "completed", - "x-ms-meta-version": "0a84439e-8a55-4b45-b30c-152bf4c097e6", + "x-ms-meta-version": "b3692c50-6ae9-4d6d-8457-16f9224f5e86", "x-ms-server-encrypted": "true", "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/model/iris_model/MLmodel", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/model/iris_model/MLmodel", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0b2 Python/3.9.6 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Wed, 12 Oct 2022 12:05:00 GMT", + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Tue, 25 Oct 2022 03:16:08 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Wed, 12 Oct 2022 12:05:00 GMT", + "Date": "Tue, 25 Oct 2022 03:16:08 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -845,9 +871,9 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "2606", + "Content-Length": "2630", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.6 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -879,7 +905,7 @@ "max_concurrency_per_instance": 2, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/db5e7941-8b47-4a43-b6ff-7c9d765449c5/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/47ddf675-0155-4289-96eb-c37908b696c0/versions/1", "entry_script": "tabular_run_with_model.py", "program_arguments": "--model ${{inputs.score_model}}", "append_row_to": "${{outputs.job_out_path}}", @@ -908,10 +934,11 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/53651e6f-94ce-4a84-a639-f24a49915b45", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/234be6de-944e-4498-bdf4-e89058b5f16c", "retry_settings": null, "logging_level": "DEBUG", - "mini_batch_size": 100 + "mini_batch_size": 100, + "partition_keys": null } }, "outputs": { @@ -929,22 +956,22 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "5076", + "Content-Length": "5101", "Content-Type": "application/json; charset=utf-8", - "Date": "Wed, 12 Oct 2022 12:05:08 GMT", + "Date": "Tue, 25 Oct 2022 03:16:17 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000?api-version=2022-10-01-preview", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-420e9be9afbd0ddc7a03fc2cf6314187-5a58598c87159a98-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-0196c27c30813249fe6054338d3733d1-dfd3fc73d0fa667a-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "93850042-5da7-483a-b999-aa19a61ec01d", - "x-ms-ratelimit-remaining-subscription-writes": "1105", + "x-ms-correlation-request-id": "a47157d1-4785-41c9-9395-59d6529fcf7b", + "x-ms-ratelimit-remaining-subscription-writes": "1196", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221012T120508Z:93850042-5da7-483a-b999-aa19a61ec01d", - "x-request-time": "3.322" + "x-ms-routing-request-id": "JAPANEAST:20221025T031618Z:a47157d1-4785-41c9-9395-59d6529fcf7b", + "x-request-time": "4.353" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/000000000000000000000", @@ -972,7 +999,7 @@ "Tracking": { "jobServiceType": "Tracking", "port": null, - "endpoint": "azureml://master.api.azureml-test.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", + "endpoint": "azureml://eastus2.api.azureml.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", "status": null, "errorMessage": null, "properties": null, @@ -1007,7 +1034,7 @@ "max_concurrency_per_instance": 2, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/db5e7941-8b47-4a43-b6ff-7c9d765449c5/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/47ddf675-0155-4289-96eb-c37908b696c0/versions/1", "entry_script": "tabular_run_with_model.py", "program_arguments": "--model ${{inputs.score_model}}", "append_row_to": "${{outputs.job_out_path}}", @@ -1036,10 +1063,11 @@ }, "properties": {}, "_source": "YAML.COMPONENT", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/53651e6f-94ce-4a84-a639-f24a49915b45", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/234be6de-944e-4498-bdf4-e89058b5f16c", "retry_settings": null, "logging_level": "DEBUG", - "mini_batch_size": 100 + "mini_batch_size": 100, + "partition_keys": null } }, "inputs": { @@ -1067,8 +1095,8 @@ "sourceJobId": null }, "systemData": { - "createdAt": "2022-10-12T12:05:07.6606876\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-10-25T03:16:17.5825052\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/pipeline_job/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_job_with_multiple_parallel_job.json b/sdk/ml/azure-ai-ml/tests/recordings/pipeline_job/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_job_with_multiple_parallel_job.json index 305aa197eea4..e1c454ba07ce 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/pipeline_job/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_job_with_multiple_parallel_job.json +++ b/sdk/ml/azure-ai-ml/tests/recordings/pipeline_job/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_job_with_multiple_parallel_job.json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,39 +15,39 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 21:07:23 GMT", + "Date": "Mon, 24 Oct 2022 13:27:48 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-2d584d332587986a5c21ce0cc4dea4f1-dc60fb69e0c119e3-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-b3b7e0a7e66fa14fb18163cb5e4738a7-2e23365960951872-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "8b12a4e2-3989-46b5-8f8a-3691f7c69a02", - "x-ms-ratelimit-remaining-subscription-reads": "11916", + "x-ms-correlation-request-id": "41e0dd21-1f26-40f5-a6f2-647252064a03", + "x-ms-ratelimit-remaining-subscription-reads": "11995", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T210724Z:8b12a4e2-3989-46b5-8f8a-3691f7c69a02", - "x-request-time": "0.045" + "x-ms-routing-request-id": "JAPANEAST:20221024T132749Z:41e0dd21-1f26-40f5-a6f2-647252064a03", + "x-request-time": "0.038" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", "name": "cpu-cluster", "type": "Microsoft.MachineLearningServices/workspaces/computes", - "location": "eastus2euap", + "location": "eastus2", "tags": {}, "properties": { - "createdOn": "2022-09-29T16:11:22.266409\u002B00:00", - "modifiedOn": "2022-09-29T16:11:25.8787166\u002B00:00", + "createdOn": "2022-09-22T03:07:49.0785672\u002B00:00", + "modifiedOn": "2022-10-11T04:29:30.5828273\u002B00:00", "disableLocalAuth": false, "description": null, "resourceId": null, "computeType": "AmlCompute", - "computeLocation": "eastus2euap", + "computeLocation": "eastus2", "provisioningState": "Succeeded", "provisioningErrors": null, "isAttachedCompute": false, @@ -60,18 +60,18 @@ "nodeIdleTimeBeforeScaleDown": "PT2M" }, "subnet": null, - "currentNodeCount": 0, - "targetNodeCount": 2, + "currentNodeCount": 2, + "targetNodeCount": 0, "nodeStateCounts": { "preparingNodeCount": 0, "runningNodeCount": 0, "idleNodeCount": 0, "unusableNodeCount": 0, - "leavingNodeCount": 0, + "leavingNodeCount": 2, "preemptedNodeCount": 0 }, "allocationState": "Resizing", - "allocationStateTransitionTime": "2022-09-29T21:06:31.764\u002B00:00", + "allocationStateTransitionTime": "2022-10-24T13:24:52.303\u002B00:00", "errors": null, "remoteLoginPortPublicAccess": "Enabled", "osType": "Linux", @@ -89,7 +89,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -97,39 +97,39 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 21:07:24 GMT", + "Date": "Mon, 24 Oct 2022 13:27:49 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-00fb13fc69e83bb8b825e0d4f5fedf28-3310974b7c59544c-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-cb4cf26f25ebcf8d9f72b2b483d81d72-f2dcb27ef712dc1e-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "37d13f7c-d05e-4210-b353-c8df00f3859c", - "x-ms-ratelimit-remaining-subscription-reads": "11915", + "x-ms-correlation-request-id": "2365d1fd-09d3-48b0-b999-b6781cecd37c", + "x-ms-ratelimit-remaining-subscription-reads": "11994", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T210724Z:37d13f7c-d05e-4210-b353-c8df00f3859c", - "x-request-time": "0.042" + "x-ms-routing-request-id": "JAPANEAST:20221024T132750Z:2365d1fd-09d3-48b0-b999-b6781cecd37c", + "x-request-time": "0.052" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", "name": "cpu-cluster", "type": "Microsoft.MachineLearningServices/workspaces/computes", - "location": "eastus2euap", + "location": "eastus2", "tags": {}, "properties": { - "createdOn": "2022-09-29T16:11:22.266409\u002B00:00", - "modifiedOn": "2022-09-29T16:11:25.8787166\u002B00:00", + "createdOn": "2022-09-22T03:07:49.0785672\u002B00:00", + "modifiedOn": "2022-10-11T04:29:30.5828273\u002B00:00", "disableLocalAuth": false, "description": null, "resourceId": null, "computeType": "AmlCompute", - "computeLocation": "eastus2euap", + "computeLocation": "eastus2", "provisioningState": "Succeeded", "provisioningErrors": null, "isAttachedCompute": false, @@ -142,18 +142,18 @@ "nodeIdleTimeBeforeScaleDown": "PT2M" }, "subnet": null, - "currentNodeCount": 0, - "targetNodeCount": 2, + "currentNodeCount": 2, + "targetNodeCount": 0, "nodeStateCounts": { "preparingNodeCount": 0, "runningNodeCount": 0, "idleNodeCount": 0, "unusableNodeCount": 0, - "leavingNodeCount": 0, + "leavingNodeCount": 2, "preemptedNodeCount": 0 }, "allocationState": "Resizing", - "allocationStateTransitionTime": "2022-09-29T21:06:31.764\u002B00:00", + "allocationStateTransitionTime": "2022-10-24T13:24:52.303\u002B00:00", "errors": null, "remoteLoginPortPublicAccess": "Enabled", "osType": "Linux", @@ -171,7 +171,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -179,39 +179,39 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 21:07:24 GMT", + "Date": "Mon, 24 Oct 2022 13:27:49 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-dd6fdabc4934219483c5926a4395e374-40f28ae227f3c0c7-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-cf29d6236631287f6c7d77697948b039-56eaef7255b8e26e-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "7cd7ea35-3906-456d-a452-c19a3c7a0f29", - "x-ms-ratelimit-remaining-subscription-reads": "11914", + "x-ms-correlation-request-id": "698a532e-b6c9-4153-b94b-d9a34473feb2", + "x-ms-ratelimit-remaining-subscription-reads": "11993", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T210724Z:7cd7ea35-3906-456d-a452-c19a3c7a0f29", - "x-request-time": "0.049" + "x-ms-routing-request-id": "JAPANEAST:20221024T132750Z:698a532e-b6c9-4153-b94b-d9a34473feb2", + "x-request-time": "0.037" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", "name": "cpu-cluster", "type": "Microsoft.MachineLearningServices/workspaces/computes", - "location": "eastus2euap", + "location": "eastus2", "tags": {}, "properties": { - "createdOn": "2022-09-29T16:11:22.266409\u002B00:00", - "modifiedOn": "2022-09-29T16:11:25.8787166\u002B00:00", + "createdOn": "2022-09-22T03:07:49.0785672\u002B00:00", + "modifiedOn": "2022-10-11T04:29:30.5828273\u002B00:00", "disableLocalAuth": false, "description": null, "resourceId": null, "computeType": "AmlCompute", - "computeLocation": "eastus2euap", + "computeLocation": "eastus2", "provisioningState": "Succeeded", "provisioningErrors": null, "isAttachedCompute": false, @@ -224,18 +224,18 @@ "nodeIdleTimeBeforeScaleDown": "PT2M" }, "subnet": null, - "currentNodeCount": 0, - "targetNodeCount": 2, + "currentNodeCount": 2, + "targetNodeCount": 0, "nodeStateCounts": { "preparingNodeCount": 0, "runningNodeCount": 0, "idleNodeCount": 0, "unusableNodeCount": 0, - "leavingNodeCount": 0, + "leavingNodeCount": 2, "preemptedNodeCount": 0 }, "allocationState": "Resizing", - "allocationStateTransitionTime": "2022-09-29T21:06:31.764\u002B00:00", + "allocationStateTransitionTime": "2022-10-24T13:24:52.303\u002B00:00", "errors": null, "remoteLoginPortPublicAccess": "Enabled", "osType": "Linux", @@ -253,7 +253,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -261,24 +261,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 21:07:25 GMT", + "Date": "Mon, 24 Oct 2022 13:27:55 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-a1e66c0945c072bb5ac15312553e7ce8-ad3d6d4efa99d194-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-ffa046ac7ccadec9d48dd4184ecc18b8-c34d0625bb3b95bf-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "f6dd317b-30e1-46a8-bb10-a20ddffb031a", - "x-ms-ratelimit-remaining-subscription-reads": "11913", + "x-ms-correlation-request-id": "832e6981-64fa-4988-bb7b-a70c19d57273", + "x-ms-ratelimit-remaining-subscription-reads": "11992", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T210725Z:f6dd317b-30e1-46a8-bb10-a20ddffb031a", - "x-request-time": "0.128" + "x-ms-routing-request-id": "JAPANEAST:20221024T132755Z:832e6981-64fa-4988-bb7b-a70c19d57273", + "x-request-time": "0.149" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -293,17 +293,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "saird7e2z7hlg4y", - "containerName": "azureml-blobstore-d8f42f37-66eb-4dca-869e-f6357989e03e", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-29T16:11:11.5415325\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-29T16:11:12.3528103\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -317,7 +317,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -325,21 +325,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 21:07:25 GMT", + "Date": "Mon, 24 Oct 2022 13:27:55 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-585876f7217e5129dd2cc3473200abcf-523eee72e54d7db7-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-c40d8cb52de08528716096e8e6b39469-005bea6e577047d6-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "8db7bb53-1771-40a3-aee9-0a06e6568d16", - "x-ms-ratelimit-remaining-subscription-writes": "1164", + "x-ms-correlation-request-id": "1838b72b-2e53-4ce2-bf43-402ca5d3a222", + "x-ms-ratelimit-remaining-subscription-writes": "1195", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T210726Z:8db7bb53-1771-40a3-aee9-0a06e6568d16", - "x-request-time": "0.107" + "x-ms-routing-request-id": "JAPANEAST:20221024T132755Z:1838b72b-2e53-4ce2-bf43-402ca5d3a222", + "x-request-time": "0.249" }, "ResponseBody": { "secretsType": "AccountKey", @@ -347,15 +347,15 @@ } }, { - "RequestUri": "https://saird7e2z7hlg4y.blob.core.windows.net/azureml-blobstore-d8f42f37-66eb-4dca-869e-f6357989e03e/LocalUpload/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 21:07:26 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:27:56 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, @@ -364,9 +364,9 @@ "Content-Length": "969", "Content-MD5": "DhunCanKGufSVuPKEYN51w==", "Content-Type": "application/octet-stream", - "Date": "Thu, 29 Sep 2022 21:07:25 GMT", - "ETag": "\u00220x8DAA24D21F8796A\u0022", - "Last-Modified": "Thu, 29 Sep 2022 19:02:19 GMT", + "Date": "Mon, 24 Oct 2022 13:27:56 GMT", + "ETag": "\u00220x8DA9D77F491F568\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:26:15 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -375,32 +375,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Thu, 29 Sep 2022 19:02:19 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:26:15 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "cd1ba5d0-716d-49b0-baa9-e0e36163afc0", + "x-ms-meta-name": "55c9c168-236e-473f-b35e-c3cba03dad49", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://saird7e2z7hlg4y.blob.core.windows.net/azureml-blobstore-d8f42f37-66eb-4dca-869e-f6357989e03e/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 21:07:26 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:27:57 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Thu, 29 Sep 2022 21:07:25 GMT", + "Date": "Mon, 24 Oct 2022 13:27:56 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -408,12 +408,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/cd1ba5d0-716d-49b0-baa9-e0e36163afc0/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -421,7 +421,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -431,7 +431,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://saird7e2z7hlg4y.blob.core.windows.net/azureml-blobstore-d8f42f37-66eb-4dca-869e-f6357989e03e/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, @@ -439,27 +439,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 21:07:26 GMT", + "Date": "Mon, 24 Oct 2022 13:27:58 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-2c702ff943a66e626931ef44c4676bc1-8c4a7257eb18b274-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-230144d1319959e9cb1779187bc47a53-4ae9c89420386242-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "9a57723b-c22d-46c6-a5ec-114d98a75dc5", - "x-ms-ratelimit-remaining-subscription-writes": "1139", + "x-ms-correlation-request-id": "af08aa28-d003-4df8-a564-2fee79746063", + "x-ms-ratelimit-remaining-subscription-writes": "1195", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T210726Z:9a57723b-c22d-46c6-a5ec-114d98a75dc5", - "x-request-time": "0.074" + "x-ms-routing-request-id": "JAPANEAST:20221024T132758Z:af08aa28-d003-4df8-a564-2fee79746063", + "x-request-time": "0.125" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/cd1ba5d0-716d-49b0-baa9-e0e36163afc0/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -471,14 +471,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://saird7e2z7hlg4y.blob.core.windows.net/azureml-blobstore-d8f42f37-66eb-4dca-869e-f6357989e03e/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-09-29T19:02:19.6417032\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-09-23T15:26:16.5278828\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-09-29T21:07:26.8679295\u002B00:00", - "lastModifiedBy": "Aditi Singhal", + "lastModifiedAt": "2022-10-24T13:27:57.9805153\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -492,7 +492,7 @@ "Connection": "keep-alive", "Content-Length": "1196", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -526,7 +526,7 @@ }, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/cd1ba5d0-716d-49b0-baa9-e0e36163afc0/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -542,26 +542,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2213", + "Content-Length": "2199", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 21:07:27 GMT", + "Date": "Mon, 24 Oct 2022 13:27:59 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-56bd5b122cf9435763b50c97784e79d7-7f928daa187e6926-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-059556d841074e50fef2ab1478caec7a-5daf4e0eccd8f564-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "12bdd9fa-0f69-44d8-8052-aab4a3b7b798", - "x-ms-ratelimit-remaining-subscription-writes": "1138", + "x-ms-correlation-request-id": "64552a27-710f-4c8f-8d55-8f7f3b85c2de", + "x-ms-ratelimit-remaining-subscription-writes": "1194", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T210727Z:12bdd9fa-0f69-44d8-8052-aab4a3b7b798", - "x-request-time": "0.372" + "x-ms-routing-request-id": "JAPANEAST:20221024T132759Z:64552a27-710f-4c8f-8d55-8f7f3b85c2de", + "x-request-time": "0.868" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/f7074ead-7150-43dd-a02b-1f2f525486de", - "name": "f7074ead-7150-43dd-a02b-1f2f525486de", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/49b5443b-115e-4f8f-ad44-df58101e0441", + "name": "49b5443b-115e-4f8f-ad44-df58101e0441", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -571,7 +571,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "f7074ead-7150-43dd-a02b-1f2f525486de", + "version": "49b5443b-115e-4f8f-ad44-df58101e0441", "display_name": "BatchScore", "is_deterministic": "True", "type": "parallel", @@ -589,8 +589,8 @@ } }, "task": { - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/cd1ba5d0-716d-49b0-baa9-e0e36163afc0/versions/1", - "environment": "azureml://registries/CuratedRegistry/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", + "environment": "azureml://registries/azureml/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "entry_script": "score.py", "type": "run_function" @@ -609,11 +609,11 @@ } }, "systemData": { - "createdAt": "2022-09-29T19:02:20.3154302\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-10-24T13:27:59.2725909\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-09-29T19:02:20.5049376\u002B00:00", - "lastModifiedBy": "Aditi Singhal", + "lastModifiedAt": "2022-10-24T13:27:59.2725909\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -625,7 +625,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -633,24 +633,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 21:07:27 GMT", + "Date": "Mon, 24 Oct 2022 13:28:00 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-a5442b642cf0ac15482e914a57ad845f-3e292e16162ee3e3-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-773d5397e58d3cc9d0931c61f53f480d-3e16f78df5dee5ad-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "941882b3-86d8-4113-b639-e60090675991", - "x-ms-ratelimit-remaining-subscription-reads": "11912", + "x-ms-correlation-request-id": "5b96ad63-2d1d-4083-b337-ced670c26717", + "x-ms-ratelimit-remaining-subscription-reads": "11991", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T210728Z:941882b3-86d8-4113-b639-e60090675991", - "x-request-time": "0.091" + "x-ms-routing-request-id": "JAPANEAST:20221024T132800Z:5b96ad63-2d1d-4083-b337-ced670c26717", + "x-request-time": "0.161" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -665,17 +665,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "saird7e2z7hlg4y", - "containerName": "azureml-blobstore-d8f42f37-66eb-4dca-869e-f6357989e03e", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-29T16:11:11.5415325\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-29T16:11:12.3528103\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -689,7 +689,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -697,21 +697,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 21:07:28 GMT", + "Date": "Mon, 24 Oct 2022 13:28:00 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-65e7db06e3f3ce4a1e2fa66a33917810-4fa013e30f46b15d-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-4bb2747fde396a8b9c394eb51bc9f575-09406876eea70b5e-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "845f27a2-739e-4d03-826e-bd1df0179735", - "x-ms-ratelimit-remaining-subscription-writes": "1163", + "x-ms-correlation-request-id": "b76d79ad-1a6a-402a-af0c-3b3fafbd5fc2", + "x-ms-ratelimit-remaining-subscription-writes": "1194", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T210728Z:845f27a2-739e-4d03-826e-bd1df0179735", - "x-request-time": "0.110" + "x-ms-routing-request-id": "JAPANEAST:20221024T132800Z:b76d79ad-1a6a-402a-af0c-3b3fafbd5fc2", + "x-request-time": "0.082" }, "ResponseBody": { "secretsType": "AccountKey", @@ -719,15 +719,15 @@ } }, { - "RequestUri": "https://saird7e2z7hlg4y.blob.core.windows.net/azureml-blobstore-d8f42f37-66eb-4dca-869e-f6357989e03e/LocalUpload/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 21:07:28 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:28:00 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, @@ -736,9 +736,9 @@ "Content-Length": "969", "Content-MD5": "DhunCanKGufSVuPKEYN51w==", "Content-Type": "application/octet-stream", - "Date": "Thu, 29 Sep 2022 21:07:28 GMT", - "ETag": "\u00220x8DAA24D21F8796A\u0022", - "Last-Modified": "Thu, 29 Sep 2022 19:02:19 GMT", + "Date": "Mon, 24 Oct 2022 13:28:00 GMT", + "ETag": "\u00220x8DA9D77F491F568\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:26:15 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -747,32 +747,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Thu, 29 Sep 2022 19:02:19 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:26:15 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "cd1ba5d0-716d-49b0-baa9-e0e36163afc0", + "x-ms-meta-name": "55c9c168-236e-473f-b35e-c3cba03dad49", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://saird7e2z7hlg4y.blob.core.windows.net/azureml-blobstore-d8f42f37-66eb-4dca-869e-f6357989e03e/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/src/convert_data.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 21:07:28 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:28:01 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Thu, 29 Sep 2022 21:07:28 GMT", + "Date": "Mon, 24 Oct 2022 13:28:00 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -780,12 +780,12 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/cd1ba5d0-716d-49b0-baa9-e0e36163afc0/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -793,7 +793,7 @@ "Connection": "keep-alive", "Content-Length": "292", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -803,7 +803,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://saird7e2z7hlg4y.blob.core.windows.net/azureml-blobstore-d8f42f37-66eb-4dca-869e-f6357989e03e/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" } }, "StatusCode": 200, @@ -811,27 +811,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 21:07:29 GMT", + "Date": "Mon, 24 Oct 2022 13:28:02 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-222cdcacfd24cd5ea022a63bc98f90d5-8f2f5ee1f995c637-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-0e184fd16b33ce0cd024f01408e5a04f-9bf95a8b9e4723eb-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "d9c7170b-5bdc-4ae1-94d8-bb9653bf28d1", - "x-ms-ratelimit-remaining-subscription-writes": "1137", + "x-ms-correlation-request-id": "72dc01c6-ef88-42d3-ad51-1c483d69a574", + "x-ms-ratelimit-remaining-subscription-writes": "1193", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T210729Z:d9c7170b-5bdc-4ae1-94d8-bb9653bf28d1", - "x-request-time": "0.108" + "x-ms-routing-request-id": "JAPANEAST:20221024T132802Z:72dc01c6-ef88-42d3-ad51-1c483d69a574", + "x-request-time": "0.118" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/cd1ba5d0-716d-49b0-baa9-e0e36163afc0/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -843,14 +843,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://saird7e2z7hlg4y.blob.core.windows.net/azureml-blobstore-d8f42f37-66eb-4dca-869e-f6357989e03e/LocalUpload/00000000000000000000000000000000/src" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/src" }, "systemData": { - "createdAt": "2022-09-29T19:02:19.6417032\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-09-23T15:26:16.5278828\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-09-29T21:07:29.5258964\u002B00:00", - "lastModifiedBy": "Aditi Singhal", + "lastModifiedAt": "2022-10-24T13:28:01.9283105\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -864,7 +864,7 @@ "Connection": "keep-alive", "Content-Length": "803", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { @@ -874,7 +874,7 @@ "isArchived": false, "componentSpec": { "command": "python convert_data.py --input_data ${{inputs.input_data}} --file_output_data ${{outputs.file_output_data}}", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/cd1ba5d0-716d-49b0-baa9-e0e36163afc0/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:5", "name": "azureml_anonymous", "tags": {}, @@ -899,26 +899,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "1821", + "Content-Length": "1808", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 21:07:30 GMT", + "Date": "Mon, 24 Oct 2022 13:28:03 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-6480338953f749445508295e3c26ab23-ce995a7e0b8ea737-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-a47c98431d55c3d58f22ae708b6fc630-acbea65549eecce8-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "47a467fc-5852-4d15-8dd1-b92243f6f9ae", - "x-ms-ratelimit-remaining-subscription-writes": "1136", + "x-ms-correlation-request-id": "510dceec-70dd-45a7-89e3-1b73e202dbf9", + "x-ms-ratelimit-remaining-subscription-writes": "1192", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T210730Z:47a467fc-5852-4d15-8dd1-b92243f6f9ae", - "x-request-time": "0.336" + "x-ms-routing-request-id": "JAPANEAST:20221024T132803Z:510dceec-70dd-45a7-89e3-1b73e202dbf9", + "x-request-time": "0.751" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/ef6b7626-aab0-4a03-a53b-5bfe9388d542", - "name": "ef6b7626-aab0-4a03-a53b-5bfe9388d542", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/c8ec2f69-f38f-4660-b8b7-a5279200e5f6", + "name": "c8ec2f69-f38f-4660-b8b7-a5279200e5f6", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -928,7 +928,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "ef6b7626-aab0-4a03-a53b-5bfe9388d542", + "version": "c8ec2f69-f38f-4660-b8b7-a5279200e5f6", "display_name": "Convert_To_Mltable_File_Dataset", "is_deterministic": "True", "type": "command", @@ -943,8 +943,8 @@ "type": "mltable" } }, - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/cd1ba5d0-716d-49b0-baa9-e0e36163afc0/versions/1", - "environment": "azureml://registries/CuratedRegistry/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/5", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", + "environment": "azureml://registries/azureml/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/5", "resources": { "instance_count": "1" }, @@ -953,11 +953,11 @@ } }, "systemData": { - "createdAt": "2022-09-29T19:02:22.594471\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-10-24T13:28:03.0735804\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-09-29T19:02:22.8131985\u002B00:00", - "lastModifiedBy": "Aditi Singhal", + "lastModifiedAt": "2022-10-24T13:28:03.0735804\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -969,7 +969,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -977,24 +977,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 21:07:30 GMT", + "Date": "Mon, 24 Oct 2022 13:28:04 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-c2a218cb13e106b838876cd0989c2db3-78f6aa86996613ff-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-7c9cea69c262b6a06f108f8d96cf64f6-5b108269b5ec3584-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "5b8f9b90-15fb-4019-a2e9-b79d3f792483", - "x-ms-ratelimit-remaining-subscription-reads": "11911", + "x-ms-correlation-request-id": "8c55d2fb-02cd-4ef0-b419-10f72eadd67c", + "x-ms-ratelimit-remaining-subscription-reads": "11990", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T210730Z:5b8f9b90-15fb-4019-a2e9-b79d3f792483", - "x-request-time": "0.085" + "x-ms-routing-request-id": "JAPANEAST:20221024T132804Z:8c55d2fb-02cd-4ef0-b419-10f72eadd67c", + "x-request-time": "0.120" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -1009,17 +1009,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "saird7e2z7hlg4y", - "containerName": "azureml-blobstore-d8f42f37-66eb-4dca-869e-f6357989e03e", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-29T16:11:11.5415325\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-29T16:11:12.3528103\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -1033,7 +1033,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -1041,21 +1041,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 21:07:30 GMT", + "Date": "Mon, 24 Oct 2022 13:28:04 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-8b94c6d68e97b723fffc56e1dd51b725-51d00a4a85ecaac1-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-1724e57dc39f1f2661e1225a537a0e0e-281c1089e0109b23-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "c402372f-2c19-481b-8621-46ea9cf73c1c", - "x-ms-ratelimit-remaining-subscription-writes": "1162", + "x-ms-correlation-request-id": "52221263-e4c9-46eb-8fa8-6ef9da9558f2", + "x-ms-ratelimit-remaining-subscription-writes": "1193", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T210731Z:c402372f-2c19-481b-8621-46ea9cf73c1c", - "x-request-time": "0.104" + "x-ms-routing-request-id": "JAPANEAST:20221024T132804Z:52221263-e4c9-46eb-8fa8-6ef9da9558f2", + "x-request-time": "0.082" }, "ResponseBody": { "secretsType": "AccountKey", @@ -1063,15 +1063,15 @@ } }, { - "RequestUri": "https://saird7e2z7hlg4y.blob.core.windows.net/azureml-blobstore-d8f42f37-66eb-4dca-869e-f6357989e03e/LocalUpload/00000000000000000000000000000000/mnist-data/0.png", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/mnist-data/0.png", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 21:07:31 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:28:04 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 200, @@ -1080,9 +1080,9 @@ "Content-Length": "223", "Content-MD5": "yLW2CQQeldeN1S7hH1/5Nw==", "Content-Type": "application/octet-stream", - "Date": "Thu, 29 Sep 2022 21:07:30 GMT", - "ETag": "\u00220x8DAA24D0513796D\u0022", - "Last-Modified": "Thu, 29 Sep 2022 19:01:30 GMT", + "Date": "Mon, 24 Oct 2022 13:28:04 GMT", + "ETag": "\u00220x8DA9D77C1560DE2\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:24:49 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -1091,32 +1091,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Thu, 29 Sep 2022 19:01:30 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:24:48 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "705e4a0e-59c6-483b-9156-af889e12f2c6", + "x-ms-meta-name": "e6954628-b564-4b7e-bf0e-472284fbfa3f", "x-ms-meta-upload_status": "completed", - "x-ms-meta-version": "31d14162-6fdf-428f-a4dc-2b3147f54dc4", + "x-ms-meta-version": "c9aa34c9-8122-4239-abd0-25287b724051", "x-ms-server-encrypted": "true", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://saird7e2z7hlg4y.blob.core.windows.net/azureml-blobstore-d8f42f37-66eb-4dca-869e-f6357989e03e/az-ml-artifacts/00000000000000000000000000000000/mnist-data/0.png", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/mnist-data/0.png", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.9.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)", - "x-ms-date": "Thu, 29 Sep 2022 21:07:31 GMT", - "x-ms-version": "2020-10-02" + "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)", + "x-ms-date": "Mon, 24 Oct 2022 13:28:05 GMT", + "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Thu, 29 Sep 2022 21:07:30 GMT", + "Date": "Mon, 24 Oct 2022 13:28:04 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -1124,27 +1124,27 @@ "Transfer-Encoding": "chunked", "Vary": "Origin", "x-ms-error-code": "BlobNotFound", - "x-ms-version": "2020-10-02" + "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_128840308393?api-version=2022-06-01-preview", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_86100095343?api-version=2022-10-01-preview", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "4248", + "Content-Length": "4295", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/0.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.5 (Windows-10-10.0.19041-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.8.13 (Windows-10-10.0.19044-SP0)" }, "RequestBody": { "properties": { "properties": {}, "tags": {}, "computeId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", - "displayName": "test_128840308393", + "displayName": "test_86100095343", "experimentName": "azure-ai-ml", "isArchived": false, "jobType": "Pipeline", @@ -1168,7 +1168,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/cd1ba5d0-716d-49b0-baa9-e0e36163afc0/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -1187,10 +1187,11 @@ "outputs": {}, "properties": {}, "_source": "YAML.JOB", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/f7074ead-7150-43dd-a02b-1f2f525486de", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/49b5443b-115e-4f8f-ad44-df58101e0441", "retry_settings": null, "logging_level": null, - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null }, "convert_data_node": { "resources": null, @@ -1215,7 +1216,7 @@ }, "properties": {}, "_source": "YAML.JOB", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/ef6b7626-aab0-4a03-a53b-5bfe9388d542" + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/c8ec2f69-f38f-4660-b8b7-a5279200e5f6" }, "file_batch_inference_duplicate_node": { "type": "parallel", @@ -1229,7 +1230,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/cd1ba5d0-716d-49b0-baa9-e0e36163afc0/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -1254,10 +1255,11 @@ }, "properties": {}, "_source": "YAML.JOB", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/f7074ead-7150-43dd-a02b-1f2f525486de", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/49b5443b-115e-4f8f-ad44-df58101e0441", "retry_settings": null, "logging_level": null, - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null } }, "outputs": { @@ -1274,26 +1276,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "7100", + "Content-Length": "7199", "Content-Type": "application/json; charset=utf-8", - "Date": "Thu, 29 Sep 2022 21:07:36 GMT", + "Date": "Mon, 24 Oct 2022 13:28:15 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_128840308393?api-version=2022-06-01-preview", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_86100095343?api-version=2022-10-01-preview", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:17d65b70-e9ce-4ed5-9347-1f660ec782e9", - "Server-Timing": "traceparent;desc=\u002200-60bd8f59f95971b795fae79d2d1f5386-57adba4dc885b0ac-01\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-97e5cef6e30c697805bfa731fbd49446-e1e8b33157ae0787-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-eastus2euap-01", + "x-aml-cluster": "vienna-eastus2-02", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "fafe49dd-3de7-4155-836e-864944d32b65", - "x-ms-ratelimit-remaining-subscription-writes": "1135", + "x-ms-correlation-request-id": "62967e78-c7f4-4e97-a9ba-3691399a2051", + "x-ms-ratelimit-remaining-subscription-writes": "1191", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "WESTUS2:20220929T210736Z:fafe49dd-3de7-4155-836e-864944d32b65", - "x-request-time": "3.647" + "x-ms-routing-request-id": "JAPANEAST:20221024T132815Z:62967e78-c7f4-4e97-a9ba-3691399a2051", + "x-request-time": "4.816" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_128840308393", - "name": "test_128840308393", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_86100095343", + "name": "test_86100095343", "type": "Microsoft.MachineLearningServices/workspaces/jobs", "properties": { "description": null, @@ -1310,25 +1312,27 @@ "azureml.defaultDataStoreName": "workspaceblobstore", "azureml.pipelineComponent": "pipelinerun" }, - "displayName": "test_128840308393", + "displayName": "test_86100095343", "status": "Preparing", "experimentName": "azure-ai-ml", "services": { "Tracking": { "jobServiceType": "Tracking", "port": null, - "endpoint": "azureml://eastus2euap.api.azureml.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", + "endpoint": "azureml://eastus2.api.azureml.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", "status": null, "errorMessage": null, - "properties": null + "properties": null, + "nodes": null }, "Studio": { "jobServiceType": "Studio", "port": null, - "endpoint": "https://ml.azure.com/runs/test_128840308393?wsid=/subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000", + "endpoint": "https://ml.azure.com/runs/test_86100095343?wsid=/subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000", "status": null, "errorMessage": null, - "properties": null + "properties": null, + "nodes": null } }, "computeId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", @@ -1352,7 +1356,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/cd1ba5d0-716d-49b0-baa9-e0e36163afc0/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -1371,10 +1375,11 @@ "outputs": {}, "properties": {}, "_source": "YAML.JOB", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/f7074ead-7150-43dd-a02b-1f2f525486de", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/49b5443b-115e-4f8f-ad44-df58101e0441", "retry_settings": null, "logging_level": null, - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null }, "convert_data_node": { "resources": null, @@ -1399,7 +1404,7 @@ }, "properties": {}, "_source": "YAML.JOB", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/ef6b7626-aab0-4a03-a53b-5bfe9388d542" + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/c8ec2f69-f38f-4660-b8b7-a5279200e5f6" }, "file_batch_inference_duplicate_node": { "type": "parallel", @@ -1413,7 +1418,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/cd1ba5d0-716d-49b0-baa9-e0e36163afc0/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/55c9c168-236e-473f-b35e-c3cba03dad49/versions/1", "entry_script": "score.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -1438,10 +1443,11 @@ }, "properties": {}, "_source": "YAML.JOB", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/f7074ead-7150-43dd-a02b-1f2f525486de", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/49b5443b-115e-4f8f-ad44-df58101e0441", "retry_settings": null, "logging_level": null, - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null } }, "inputs": { @@ -1463,14 +1469,14 @@ "sourceJobId": null }, "systemData": { - "createdAt": "2022-09-29T21:07:36.5670477\u002B00:00", - "createdBy": "Aditi Singhal", + "createdAt": "2022-10-24T13:28:14.9675312\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User" } } } ], "Variables": { - "name": "test_128840308393" + "name": "test_86100095343" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/pipeline_job/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_job_with_parallel_job[file_component_input_e2e.yml].json b/sdk/ml/azure-ai-ml/tests/recordings/pipeline_job/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_job_with_parallel_job[file_component_input_e2e.yml].json index 9f913902d75b..fdd224ceb724 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/pipeline_job/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_job_with_parallel_job[file_component_input_e2e.yml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/pipeline_job/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_job_with_parallel_job[file_component_input_e2e.yml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,39 +15,39 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:03 GMT", + "Date": "Wed, 26 Oct 2022 06:13:52 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-622f2093f0982fb71bd1623411c74655-3fe3c5feee412704-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-c251f94da7870380ae713cf67c1fdae5-d49e53b1ce7057af-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "a9db36b8-1f37-4270-9bb3-6e8e915df234", - "x-ms-ratelimit-remaining-subscription-reads": "11999", + "x-ms-correlation-request-id": "5aaef285-ed84-49ea-a5f4-66a2ee81fa88", + "x-ms-ratelimit-remaining-subscription-reads": "11992", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045903Z:a9db36b8-1f37-4270-9bb3-6e8e915df234", - "x-request-time": "0.211" + "x-ms-routing-request-id": "JAPANEAST:20221026T061352Z:5aaef285-ed84-49ea-a5f4-66a2ee81fa88", + "x-request-time": "0.033" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", "name": "cpu-cluster", "type": "Microsoft.MachineLearningServices/workspaces/computes", - "location": "centraluseuap", + "location": "eastus2", "tags": {}, "properties": { - "createdOn": "2022-09-22T09:02:22.1899959\u002B00:00", - "modifiedOn": "2022-09-23T03:28:18.0066218\u002B00:00", + "createdOn": "2022-09-22T03:07:49.0785672\u002B00:00", + "modifiedOn": "2022-10-11T04:29:30.5828273\u002B00:00", "disableLocalAuth": false, "description": null, "resourceId": null, "computeType": "AmlCompute", - "computeLocation": "centraluseuap", + "computeLocation": "eastus2", "provisioningState": "Succeeded", "provisioningErrors": null, "isAttachedCompute": false, @@ -56,22 +56,22 @@ "vmPriority": "Dedicated", "scaleSettings": { "maxNodeCount": 4, - "minNodeCount": 1, + "minNodeCount": 0, "nodeIdleTimeBeforeScaleDown": "PT2M" }, "subnet": null, - "currentNodeCount": 4, - "targetNodeCount": 4, + "currentNodeCount": 0, + "targetNodeCount": 0, "nodeStateCounts": { "preparingNodeCount": 0, - "runningNodeCount": 4, + "runningNodeCount": 0, "idleNodeCount": 0, "unusableNodeCount": 0, "leavingNodeCount": 0, "preemptedNodeCount": 0 }, "allocationState": "Steady", - "allocationStateTransitionTime": "2022-10-21T06:50:04.626\u002B00:00", + "allocationStateTransitionTime": "2022-10-25T06:07:12.361\u002B00:00", "errors": null, "remoteLoginPortPublicAccess": "Enabled", "osType": "Linux", @@ -89,7 +89,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -97,24 +97,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:05 GMT", + "Date": "Wed, 26 Oct 2022 06:13:55 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-8aecfa09298372973bcbf4606e9db4a2-ef430028b16881f9-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-ec3189d207c32e5b964feccdd50ea1c0-f859927395c31e00-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "dc02b58a-03b1-439a-8b47-f83b9472a17f", - "x-ms-ratelimit-remaining-subscription-reads": "11998", + "x-ms-correlation-request-id": "fac511d5-665b-493e-8702-645501dff549", + "x-ms-ratelimit-remaining-subscription-reads": "11991", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045905Z:dc02b58a-03b1-439a-8b47-f83b9472a17f", - "x-request-time": "0.140" + "x-ms-routing-request-id": "JAPANEAST:20221026T061356Z:fac511d5-665b-493e-8702-645501dff549", + "x-request-time": "0.837" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -129,17 +129,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -153,7 +153,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -161,21 +161,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:06 GMT", + "Date": "Wed, 26 Oct 2022 06:13:57 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-1c754f88963e3ed9dfedc55d9be65e01-bbe9b16a50515a9a-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-3fdd50bfae858852c90283d3ccaaf4c9-950f18f9d9f486bc-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "4f8b622d-489c-4471-bb3f-8a967fe7973c", + "x-ms-correlation-request-id": "563a0969-b189-496f-8ba2-b3d7bd19fb2c", "x-ms-ratelimit-remaining-subscription-writes": "1199", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045906Z:4f8b622d-489c-4471-bb3f-8a967fe7973c", - "x-request-time": "0.147" + "x-ms-routing-request-id": "JAPANEAST:20221026T061357Z:563a0969-b189-496f-8ba2-b3d7bd19fb2c", + "x-request-time": "0.712" }, "ResponseBody": { "secretsType": "AccountKey", @@ -183,14 +183,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/script_parallel/digit_identification.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/script_parallel/digit_identification.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Mon, 24 Oct 2022 04:59:06 GMT", + "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.10.8 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Wed, 26 Oct 2022 06:13:57 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -200,9 +200,9 @@ "Content-Length": "1555", "Content-MD5": "4WzoZGSMp9zEx3G4j/SVnA==", "Content-Type": "application/octet-stream", - "Date": "Mon, 24 Oct 2022 04:59:07 GMT", - "ETag": "\u00220x8DA9D49D7EAA27E\u0022", - "Last-Modified": "Fri, 23 Sep 2022 09:56:10 GMT", + "Date": "Wed, 26 Oct 2022 06:13:58 GMT", + "ETag": "\u00220x8DA9D77BDF33C17\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:24:43 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -211,10 +211,10 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Fri, 23 Sep 2022 09:56:10 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:24:42 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "88bd524f-9c9e-4b52-9a39-a18be7c95512", + "x-ms-meta-name": "430c0a29-9981-4727-b4a5-8fa454b267c3", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", @@ -223,20 +223,20 @@ "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/script_parallel/digit_identification.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/script_parallel/digit_identification.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Mon, 24 Oct 2022 04:59:07 GMT", + "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.10.8 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Wed, 26 Oct 2022 06:13:58 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 24 Oct 2022 04:59:07 GMT", + "Date": "Wed, 26 Oct 2022 06:13:58 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -249,7 +249,7 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -257,7 +257,7 @@ "Connection": "keep-alive", "Content-Length": "304", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -267,7 +267,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/script_parallel" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/script_parallel" } }, "StatusCode": 200, @@ -275,27 +275,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:09 GMT", + "Date": "Wed, 26 Oct 2022 06:14:00 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-1348a8a17ba8843c339e00284912bc29-e33d7dd764fcf9ed-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-66cea031632c292334be0ed794033f9f-7b89e91efe9d7ebf-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "71998a60-a55e-41cf-916c-581733c74a5d", + "x-ms-correlation-request-id": "9e2054a6-b7ba-4861-84d9-e5a9844e5b56", "x-ms-ratelimit-remaining-subscription-writes": "1199", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045909Z:71998a60-a55e-41cf-916c-581733c74a5d", - "x-request-time": "0.473" + "x-ms-routing-request-id": "JAPANEAST:20221026T061400Z:9e2054a6-b7ba-4861-84d9-e5a9844e5b56", + "x-request-time": "0.724" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -307,14 +307,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/script_parallel" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/script_parallel" }, "systemData": { - "createdAt": "2022-09-23T09:56:12.0126883\u002B00:00", - "createdBy": "Ying Chen", + "createdAt": "2022-09-23T15:24:44.8270903\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-10-24T04:59:08.9221332\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-26T06:14:00.1985097\u002B00:00", + "lastModifiedBy": "Clement Wang", "lastModifiedByType": "User" } } @@ -328,7 +328,7 @@ "Connection": "keep-alive", "Content-Length": "1307", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -363,7 +363,7 @@ "logging_level": "WARNING", "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1", "entry_script": "pass_through.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -384,26 +384,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2219", + "Content-Length": "2209", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:10 GMT", + "Date": "Wed, 26 Oct 2022 06:14:02 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-dc733282d64dc484f1ae06199376da0c-a5eeff4c09461b59-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-901d6e6f145c48d51984013a54df1cd5-86a2f12d99a193c1-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "c6536cf8-5369-4088-a138-cda212b57f69", + "x-ms-correlation-request-id": "378b0804-372d-4387-a8a8-66f82b16f59a", "x-ms-ratelimit-remaining-subscription-writes": "1198", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045910Z:c6536cf8-5369-4088-a138-cda212b57f69", - "x-request-time": "1.295" + "x-ms-routing-request-id": "JAPANEAST:20221026T061402Z:378b0804-372d-4387-a8a8-66f82b16f59a", + "x-request-time": "1.745" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/359ecd68-8232-4b53-9230-bb26ddb80a6b", - "name": "359ecd68-8232-4b53-9230-bb26ddb80a6b", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/9ea8b623-d29b-4708-8294-e410178705f0", + "name": "9ea8b623-d29b-4708-8294-e410178705f0", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -413,7 +413,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "359ecd68-8232-4b53-9230-bb26ddb80a6b", + "version": "9ea8b623-d29b-4708-8294-e410178705f0", "display_name": "BatchScore", "is_deterministic": "True", "type": "parallel", @@ -431,8 +431,8 @@ } }, "task": { - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1", - "environment": "azureml://registries/azureml-dev/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1", + "environment": "azureml://registries/azureml/environments/AzureML-sklearn-0.24-ubuntu18.04-py37-cpu/versions/1", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "entry_script": "pass_through.py", "type": "run_function" @@ -451,11 +451,11 @@ } }, "systemData": { - "createdAt": "2022-10-12T03:00:33.3557292\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-10-25T05:52:47.2219256\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-10-12T03:00:33.8347407\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-25T05:52:47.4200101\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -467,7 +467,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -475,24 +475,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:11 GMT", + "Date": "Wed, 26 Oct 2022 06:14:04 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-4dca8c2d9d705dbc6347c687297a03f8-f482218bc7a2b444-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-c5c57de6fc2abb7942962a7596bf2def-9c836b88c2bb1cba-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "9ad7b9d2-a6ec-4122-abbc-e27b9491b379", - "x-ms-ratelimit-remaining-subscription-reads": "11997", + "x-ms-correlation-request-id": "cc55d7b2-3447-4512-a90b-e22a48cae303", + "x-ms-ratelimit-remaining-subscription-reads": "11990", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045911Z:9ad7b9d2-a6ec-4122-abbc-e27b9491b379", - "x-request-time": "0.192" + "x-ms-routing-request-id": "JAPANEAST:20221026T061404Z:cc55d7b2-3447-4512-a90b-e22a48cae303", + "x-request-time": "0.120" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -507,17 +507,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -531,7 +531,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -539,21 +539,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:12 GMT", + "Date": "Wed, 26 Oct 2022 06:14:04 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-90abd733a49ed72ca755bd9fcac49777-d628e219204d1fec-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-db8f4ea066ab132288db02e87ad7a364-cfbb27f582857b82-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "dfb82e20-bbb9-4bdd-9b40-feef099f7c4f", + "x-ms-correlation-request-id": "55339899-f9b4-4eba-b954-aea2bc615271", "x-ms-ratelimit-remaining-subscription-writes": "1198", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045912Z:dfb82e20-bbb9-4bdd-9b40-feef099f7c4f", - "x-request-time": "0.112" + "x-ms-routing-request-id": "JAPANEAST:20221026T061405Z:55339899-f9b4-4eba-b954-aea2bc615271", + "x-request-time": "0.200" }, "ResponseBody": { "secretsType": "AccountKey", @@ -561,14 +561,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/mnist-data/0.png", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/mnist-data/0.png", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Mon, 24 Oct 2022 04:59:12 GMT", + "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.10.8 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Wed, 26 Oct 2022 06:14:05 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -578,9 +578,9 @@ "Content-Length": "223", "Content-MD5": "yLW2CQQeldeN1S7hH1/5Nw==", "Content-Type": "application/octet-stream", - "Date": "Mon, 24 Oct 2022 04:59:12 GMT", - "ETag": "\u00220x8DA9D49DDA8E2B9\u0022", - "Last-Modified": "Fri, 23 Sep 2022 09:56:20 GMT", + "Date": "Wed, 26 Oct 2022 06:14:05 GMT", + "ETag": "\u00220x8DA9D77C1560DE2\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:24:49 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -589,32 +589,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Fri, 23 Sep 2022 09:56:19 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:24:48 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "6d38069b-69f7-4247-bed0-fffe996f3098", + "x-ms-meta-name": "e6954628-b564-4b7e-bf0e-472284fbfa3f", "x-ms-meta-upload_status": "completed", - "x-ms-meta-version": "315ab246-e719-41ed-9ad8-28f2f315a8e2", + "x-ms-meta-version": "c9aa34c9-8122-4239-abd0-25287b724051", "x-ms-server-encrypted": "true", "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/mnist-data/0.png", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/mnist-data/0.png", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Mon, 24 Oct 2022 04:59:12 GMT", + "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.10.8 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Wed, 26 Oct 2022 06:14:05 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 24 Oct 2022 04:59:12 GMT", + "Date": "Wed, 26 Oct 2022 06:14:05 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -627,15 +627,15 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_654727691512?api-version=2022-10-01-preview", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_487157387600?api-version=2022-10-01-preview", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "2134", + "Content-Length": "2158", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -645,7 +645,7 @@ "tag": "tagvalue", "owner": "sdkteam" }, - "displayName": "test_654727691512", + "displayName": "test_487157387600", "experimentName": "azure-ai-ml", "isArchived": false, "jobType": "Pipeline", @@ -669,7 +669,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1", "entry_script": "pass_through.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -688,10 +688,11 @@ "outputs": {}, "properties": {}, "_source": "YAML.JOB", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/359ecd68-8232-4b53-9230-bb26ddb80a6b", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/9ea8b623-d29b-4708-8294-e410178705f0", "retry_settings": null, "logging_level": null, - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null } }, "outputs": {}, @@ -704,26 +705,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "4354", + "Content-Length": "4381", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:22 GMT", + "Date": "Wed, 26 Oct 2022 06:14:17 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_654727691512?api-version=2022-10-01-preview", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_487157387600?api-version=2022-10-01-preview", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-6168c598f9f2caaf78c5f6bb84e7eee0-992ecb578aa67c16-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-8dae7a1d4c377803eac78184f2f245cb-be1a9fe3b63121ab-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "e3c8ed8a-d7d4-49dd-ac0b-989521294279", + "x-ms-correlation-request-id": "13ec9ba6-f3ac-432d-96d0-53ee690deb1d", "x-ms-ratelimit-remaining-subscription-writes": "1197", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045922Z:e3c8ed8a-d7d4-49dd-ac0b-989521294279", - "x-request-time": "5.890" + "x-ms-routing-request-id": "JAPANEAST:20221026T061417Z:13ec9ba6-f3ac-432d-96d0-53ee690deb1d", + "x-request-time": "5.041" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_654727691512", - "name": "test_654727691512", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_487157387600", + "name": "test_487157387600", "type": "Microsoft.MachineLearningServices/workspaces/jobs", "properties": { "description": "The hello world pipeline job with inline parallel job defined by parallel component", @@ -743,14 +744,14 @@ "azureml.defaultDataStoreName": "workspaceblobstore", "azureml.pipelineComponent": "pipelinerun" }, - "displayName": "test_654727691512", + "displayName": "test_487157387600", "status": "Preparing", "experimentName": "azure-ai-ml", "services": { "Tracking": { "jobServiceType": "Tracking", "port": null, - "endpoint": "azureml://master.api.azureml-test.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", + "endpoint": "azureml://eastus2.api.azureml.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", "status": null, "errorMessage": null, "properties": null, @@ -759,7 +760,7 @@ "Studio": { "jobServiceType": "Studio", "port": null, - "endpoint": "https://ml.azure.com/runs/test_654727691512?wsid=/subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000", + "endpoint": "https://ml.azure.com/runs/test_487157387600?wsid=/subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000", "status": null, "errorMessage": null, "properties": null, @@ -788,7 +789,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1", "entry_script": "pass_through.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:AzureML-sklearn-0.24-ubuntu18.04-py37-cpu:1" @@ -807,10 +808,11 @@ "outputs": {}, "properties": {}, "_source": "YAML.JOB", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/359ecd68-8232-4b53-9230-bb26ddb80a6b", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/9ea8b623-d29b-4708-8294-e410178705f0", "retry_settings": null, "logging_level": null, - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null } }, "inputs": { @@ -825,14 +827,14 @@ "sourceJobId": null }, "systemData": { - "createdAt": "2022-10-24T04:59:20.6154414\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-10-26T06:14:17.4276117\u002B00:00", + "createdBy": "Clement Wang", "createdByType": "User" } } } ], "Variables": { - "name": "test_654727691512" + "name": "test_487157387600" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/pipeline_job/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_job_with_parallel_job[file_input_e2e.yml].json b/sdk/ml/azure-ai-ml/tests/recordings/pipeline_job/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_job_with_parallel_job[file_input_e2e.yml].json index 7875576c57d5..a925a2adecff 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/pipeline_job/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_job_with_parallel_job[file_input_e2e.yml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/pipeline_job/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_job_with_parallel_job[file_input_e2e.yml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,39 +15,39 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:27 GMT", + "Date": "Wed, 26 Oct 2022 06:14:24 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-5798737624437b67f1924206a23c85e0-14a8b8b3f37b6d7f-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-2d65396c4be593878dcecd0a4244aad1-c98ec0c45fceed91-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "c252657c-7aaa-4b73-ac9a-ac9d57c8a5a7", - "x-ms-ratelimit-remaining-subscription-reads": "11996", + "x-ms-correlation-request-id": "c14f0847-7d99-4b8f-8c2d-4255980977a1", + "x-ms-ratelimit-remaining-subscription-reads": "11988", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045927Z:c252657c-7aaa-4b73-ac9a-ac9d57c8a5a7", - "x-request-time": "0.216" + "x-ms-routing-request-id": "JAPANEAST:20221026T061424Z:c14f0847-7d99-4b8f-8c2d-4255980977a1", + "x-request-time": "0.076" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", "name": "cpu-cluster", "type": "Microsoft.MachineLearningServices/workspaces/computes", - "location": "centraluseuap", + "location": "eastus2", "tags": {}, "properties": { - "createdOn": "2022-09-22T09:02:22.1899959\u002B00:00", - "modifiedOn": "2022-09-23T03:28:18.0066218\u002B00:00", + "createdOn": "2022-09-22T03:07:49.0785672\u002B00:00", + "modifiedOn": "2022-10-11T04:29:30.5828273\u002B00:00", "disableLocalAuth": false, "description": null, "resourceId": null, "computeType": "AmlCompute", - "computeLocation": "centraluseuap", + "computeLocation": "eastus2", "provisioningState": "Succeeded", "provisioningErrors": null, "isAttachedCompute": false, @@ -56,22 +56,22 @@ "vmPriority": "Dedicated", "scaleSettings": { "maxNodeCount": 4, - "minNodeCount": 1, + "minNodeCount": 0, "nodeIdleTimeBeforeScaleDown": "PT2M" }, "subnet": null, - "currentNodeCount": 4, - "targetNodeCount": 4, + "currentNodeCount": 0, + "targetNodeCount": 0, "nodeStateCounts": { "preparingNodeCount": 0, - "runningNodeCount": 4, + "runningNodeCount": 0, "idleNodeCount": 0, "unusableNodeCount": 0, "leavingNodeCount": 0, "preemptedNodeCount": 0 }, "allocationState": "Steady", - "allocationStateTransitionTime": "2022-10-21T06:50:04.626\u002B00:00", + "allocationStateTransitionTime": "2022-10-25T06:07:12.361\u002B00:00", "errors": null, "remoteLoginPortPublicAccess": "Enabled", "osType": "Linux", @@ -89,7 +89,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -97,24 +97,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:29 GMT", + "Date": "Wed, 26 Oct 2022 06:14:26 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-fa0b845f372a19eeb9254b00695d4509-0c0ea38bbc0b57ca-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-83693da758ef22bbbbc7d2690b743a53-756238c71b05188d-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "e11437a5-e92a-47ce-83a0-3f7ca1a97b8e", - "x-ms-ratelimit-remaining-subscription-reads": "11995", + "x-ms-correlation-request-id": "59babb1d-7432-4401-ab06-5dc375b27594", + "x-ms-ratelimit-remaining-subscription-reads": "11987", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045929Z:e11437a5-e92a-47ce-83a0-3f7ca1a97b8e", - "x-request-time": "0.125" + "x-ms-routing-request-id": "JAPANEAST:20221026T061427Z:59babb1d-7432-4401-ab06-5dc375b27594", + "x-request-time": "0.114" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -129,17 +129,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -153,7 +153,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -161,21 +161,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:29 GMT", + "Date": "Wed, 26 Oct 2022 06:14:27 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-2d22aea70b7eff3c26b0ce32ff57ffb2-021a72619123641f-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-e6b3b52c17b0b4fdda55a6eb03fd1bf7-14ed584fadaaa311-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "09fc211d-c4ae-47df-ab82-35b96021191e", + "x-ms-correlation-request-id": "9ea90165-970a-4d51-b65d-eaab3f6f578c", "x-ms-ratelimit-remaining-subscription-writes": "1197", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045930Z:09fc211d-c4ae-47df-ab82-35b96021191e", - "x-request-time": "0.117" + "x-ms-routing-request-id": "JAPANEAST:20221026T061427Z:9ea90165-970a-4d51-b65d-eaab3f6f578c", + "x-request-time": "0.097" }, "ResponseBody": { "secretsType": "AccountKey", @@ -183,14 +183,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/script_parallel/digit_identification.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/script_parallel/digit_identification.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Mon, 24 Oct 2022 04:59:30 GMT", + "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.10.8 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Wed, 26 Oct 2022 06:14:27 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -200,9 +200,9 @@ "Content-Length": "1555", "Content-MD5": "4WzoZGSMp9zEx3G4j/SVnA==", "Content-Type": "application/octet-stream", - "Date": "Mon, 24 Oct 2022 04:59:30 GMT", - "ETag": "\u00220x8DA9D49D7EAA27E\u0022", - "Last-Modified": "Fri, 23 Sep 2022 09:56:10 GMT", + "Date": "Wed, 26 Oct 2022 06:14:27 GMT", + "ETag": "\u00220x8DA9D77BDF33C17\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:24:43 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -211,10 +211,10 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Fri, 23 Sep 2022 09:56:10 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:24:42 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "88bd524f-9c9e-4b52-9a39-a18be7c95512", + "x-ms-meta-name": "430c0a29-9981-4727-b4a5-8fa454b267c3", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", @@ -223,20 +223,20 @@ "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/script_parallel/digit_identification.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/script_parallel/digit_identification.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Mon, 24 Oct 2022 04:59:30 GMT", + "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.10.8 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Wed, 26 Oct 2022 06:14:28 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 24 Oct 2022 04:59:30 GMT", + "Date": "Wed, 26 Oct 2022 06:14:28 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -249,7 +249,7 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -257,7 +257,7 @@ "Connection": "keep-alive", "Content-Length": "304", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -267,7 +267,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/script_parallel" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/script_parallel" } }, "StatusCode": 200, @@ -275,27 +275,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:31 GMT", + "Date": "Wed, 26 Oct 2022 06:14:28 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-11f7920e2ddddd457250083260e2df79-0e381505ce9d3f5a-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-c2913795dc6853fe233d6a1f995e8a5a-eeb6b2fcc97d82e6-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "a90b96a7-9627-44e4-a543-b4b4c16e6d4d", + "x-ms-correlation-request-id": "903d68bd-16d6-485f-965c-1bd44ebb411d", "x-ms-ratelimit-remaining-subscription-writes": "1196", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045931Z:a90b96a7-9627-44e4-a543-b4b4c16e6d4d", - "x-request-time": "0.349" + "x-ms-routing-request-id": "JAPANEAST:20221026T061428Z:903d68bd-16d6-485f-965c-1bd44ebb411d", + "x-request-time": "0.071" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -307,14 +307,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/script_parallel" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/script_parallel" }, "systemData": { - "createdAt": "2022-09-23T09:56:12.0126883\u002B00:00", - "createdBy": "Ying Chen", + "createdAt": "2022-09-23T15:24:44.8270903\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-10-24T04:59:31.1897995\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-26T06:14:28.6641991\u002B00:00", + "lastModifiedBy": "Clement Wang", "lastModifiedByType": "User" } } @@ -328,7 +328,7 @@ "Connection": "keep-alive", "Content-Length": "416", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -340,24 +340,24 @@ }, "StatusCode": 201, "ResponseHeaders": { - "Build-ID": "cav", + "Build-ID": "chv", "Cache-Control": "no-cache", - "Content-Length": "1351", + "Content-Length": "1359", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:44 GMT", + "Date": "Wed, 26 Oct 2022 06:14:41 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-980d927379acf62d9d891e5e60abfa65-ca02cd70795812fd-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-53e780bab76ecfc01ba75170ebe98f72-cd7a750870eb2f76-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "d35a4002-beed-4ab4-9090-25fb3239f57a", + "x-ms-correlation-request-id": "2abba4b4-d942-44ac-abfb-100e0fabfcb6", "x-ms-ratelimit-remaining-subscription-writes": "1195", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045944Z:d35a4002-beed-4ab4-9090-25fb3239f57a", - "x-request-time": "13.154" + "x-ms-routing-request-id": "JAPANEAST:20221026T061441Z:2abba4b4-d942-44ac-abfb-100e0fabfcb6", + "x-request-time": "12.396" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af", @@ -375,11 +375,11 @@ "osType": "Linux" }, "systemData": { - "createdAt": "2022-09-23T09:56:46.9554352\u002B00:00", - "createdBy": "Ying Chen", + "createdAt": "2022-09-23T15:25:10.3353821\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-09-23T09:56:46.9554352\u002B00:00", - "lastModifiedBy": "Ying Chen", + "lastModifiedAt": "2022-09-23T15:25:10.3353821\u002B00:00", + "lastModifiedBy": "Zhengfei Wang", "lastModifiedByType": "User" } } @@ -393,7 +393,7 @@ "Connection": "keep-alive", "Content-Length": "1313", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -426,7 +426,7 @@ "logging_level": "WARNING", "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1", "entry_script": "pass_through.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af" @@ -447,26 +447,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2250", + "Content-Length": "2252", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:45 GMT", + "Date": "Wed, 26 Oct 2022 06:14:42 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-107bf60f7be17bb11edebe3e100d04aa-a2cc1db5eada8e2a-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-6ea255616bdeb99c10be2c030c4bbc58-4736cf0c247663f0-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "49885481-4e37-4adf-9f21-56d8cbd78493", + "x-ms-correlation-request-id": "07e584d3-9efd-4c3a-960a-b1b055ca64c8", "x-ms-ratelimit-remaining-subscription-writes": "1194", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045945Z:49885481-4e37-4adf-9f21-56d8cbd78493", - "x-request-time": "0.520" + "x-ms-routing-request-id": "JAPANEAST:20221026T061442Z:07e584d3-9efd-4c3a-960a-b1b055ca64c8", + "x-request-time": "0.382" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/a45d2fb0-2ba9-43a7-84fa-11485f872136", - "name": "a45d2fb0-2ba9-43a7-84fa-11485f872136", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/fd0d9e96-ca9a-4e00-89b9-946db3a04fda", + "name": "fd0d9e96-ca9a-4e00-89b9-946db3a04fda", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -476,7 +476,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "a45d2fb0-2ba9-43a7-84fa-11485f872136", + "version": "fd0d9e96-ca9a-4e00-89b9-946db3a04fda", "display_name": "hello_world_inline_parallel_file_job_1", "is_deterministic": "True", "type": "parallel", @@ -492,7 +492,7 @@ } }, "task": { - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1", "environment": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "entry_script": "pass_through.py", @@ -512,11 +512,11 @@ } }, "systemData": { - "createdAt": "2022-09-23T09:57:01.2645092\u002B00:00", - "createdBy": "Ying Chen", + "createdAt": "2022-10-25T05:53:22.8744054\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-09-23T09:57:01.7809359\u002B00:00", - "lastModifiedBy": "Ying Chen", + "lastModifiedAt": "2022-10-25T05:53:23.0526384\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -528,7 +528,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -536,24 +536,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:46 GMT", + "Date": "Wed, 26 Oct 2022 06:14:42 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-a50457ad9483071f48417e8be47bebb0-62847a602b07dd4f-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-5dc098c8db9a5d37fdd087c3b6d30396-f57b9569d1f48ef8-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "b03746a4-13b3-4167-8594-1ad627deff69", - "x-ms-ratelimit-remaining-subscription-reads": "11994", + "x-ms-correlation-request-id": "d25992fb-1ad5-481e-b3ed-eb798e32d750", + "x-ms-ratelimit-remaining-subscription-reads": "11986", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045946Z:b03746a4-13b3-4167-8594-1ad627deff69", - "x-request-time": "0.127" + "x-ms-routing-request-id": "JAPANEAST:20221026T061443Z:d25992fb-1ad5-481e-b3ed-eb798e32d750", + "x-request-time": "0.107" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -568,17 +568,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -592,7 +592,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -600,21 +600,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:46 GMT", + "Date": "Wed, 26 Oct 2022 06:14:43 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-585fde2d1eb3a5801bf832c9c56fc760-c63b4534ae4681e4-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-3c118625d761179b2931694bd494dcf5-8b068475593e2332-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "b5159cff-7e69-4c28-b72d-9a034f6ce8e3", + "x-ms-correlation-request-id": "1454d2a9-cd1d-4a22-9e69-1b44fd892b55", "x-ms-ratelimit-remaining-subscription-writes": "1196", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045947Z:b5159cff-7e69-4c28-b72d-9a034f6ce8e3", - "x-request-time": "0.504" + "x-ms-routing-request-id": "JAPANEAST:20221026T061443Z:1454d2a9-cd1d-4a22-9e69-1b44fd892b55", + "x-request-time": "0.156" }, "ResponseBody": { "secretsType": "AccountKey", @@ -622,14 +622,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/mnist-data/0.png", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/mnist-data/0.png", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Mon, 24 Oct 2022 04:59:47 GMT", + "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.10.8 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Wed, 26 Oct 2022 06:14:43 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -639,9 +639,9 @@ "Content-Length": "223", "Content-MD5": "yLW2CQQeldeN1S7hH1/5Nw==", "Content-Type": "application/octet-stream", - "Date": "Mon, 24 Oct 2022 04:59:47 GMT", - "ETag": "\u00220x8DA9D49DDA8E2B9\u0022", - "Last-Modified": "Fri, 23 Sep 2022 09:56:20 GMT", + "Date": "Wed, 26 Oct 2022 06:14:43 GMT", + "ETag": "\u00220x8DA9D77C1560DE2\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:24:49 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -650,32 +650,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Fri, 23 Sep 2022 09:56:19 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:24:48 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "6d38069b-69f7-4247-bed0-fffe996f3098", + "x-ms-meta-name": "e6954628-b564-4b7e-bf0e-472284fbfa3f", "x-ms-meta-upload_status": "completed", - "x-ms-meta-version": "315ab246-e719-41ed-9ad8-28f2f315a8e2", + "x-ms-meta-version": "c9aa34c9-8122-4239-abd0-25287b724051", "x-ms-server-encrypted": "true", "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/mnist-data/0.png", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/mnist-data/0.png", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Mon, 24 Oct 2022 04:59:47 GMT", + "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.10.8 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Wed, 26 Oct 2022 06:14:44 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 24 Oct 2022 04:59:47 GMT", + "Date": "Wed, 26 Oct 2022 06:14:44 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -688,15 +688,15 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_177211603418?api-version=2022-10-01-preview", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_402372530826?api-version=2022-10-01-preview", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "2292", + "Content-Length": "2316", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -706,7 +706,7 @@ "tag": "tagvalue", "owner": "sdkteam" }, - "displayName": "test_177211603418", + "displayName": "test_402372530826", "experimentName": "azure-ai-ml", "isArchived": false, "jobType": "Pipeline", @@ -732,7 +732,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1", "entry_script": "pass_through.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af" @@ -756,13 +756,14 @@ }, "properties": {}, "_source": "YAML.JOB", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/a45d2fb0-2ba9-43a7-84fa-11485f872136", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/fd0d9e96-ca9a-4e00-89b9-946db3a04fda", "retry_settings": { "timeout": 60, "max_retries": 2 }, "logging_level": "WARNING", - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null } }, "outputs": { @@ -779,26 +780,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "4645", + "Content-Length": "4674", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 04:59:55 GMT", + "Date": "Wed, 26 Oct 2022 06:14:51 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_177211603418?api-version=2022-10-01-preview", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_402372530826?api-version=2022-10-01-preview", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-50031bba991f41b3ed43e39dd6e18366-8e881b1e49d34c64-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-97fd24251298375c290c90cdec6c12af-537f9faab1e59332-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "f6ebd069-b13c-4701-ae8b-2aa87e381443", + "x-ms-correlation-request-id": "14637ea2-7dd4-456d-ae33-abe4969ce51e", "x-ms-ratelimit-remaining-subscription-writes": "1193", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T045956Z:f6ebd069-b13c-4701-ae8b-2aa87e381443", - "x-request-time": "4.571" + "x-ms-routing-request-id": "JAPANEAST:20221026T061452Z:14637ea2-7dd4-456d-ae33-abe4969ce51e", + "x-request-time": "3.154" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_177211603418", - "name": "test_177211603418", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_402372530826", + "name": "test_402372530826", "type": "Microsoft.MachineLearningServices/workspaces/jobs", "properties": { "description": "The hello world pipeline job with inline parallel job", @@ -817,14 +818,14 @@ "azureml.defaultDataStoreName": "workspaceblobstore", "azureml.pipelineComponent": "pipelinerun" }, - "displayName": "test_177211603418", - "status": "Running", + "displayName": "test_402372530826", + "status": "Preparing", "experimentName": "azure-ai-ml", "services": { "Tracking": { "jobServiceType": "Tracking", "port": null, - "endpoint": "azureml://master.api.azureml-test.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", + "endpoint": "azureml://eastus2.api.azureml.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", "status": null, "errorMessage": null, "properties": null, @@ -833,7 +834,7 @@ "Studio": { "jobServiceType": "Studio", "port": null, - "endpoint": "https://ml.azure.com/runs/test_177211603418?wsid=/subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000", + "endpoint": "https://ml.azure.com/runs/test_402372530826?wsid=/subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000", "status": null, "errorMessage": null, "properties": null, @@ -863,7 +864,7 @@ "max_concurrency_per_instance": 1, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1", "entry_script": "pass_through.py", "program_arguments": "--job_output_path ${{outputs.job_output_path}}", "environment": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af" @@ -887,13 +888,14 @@ }, "properties": {}, "_source": "YAML.JOB", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/a45d2fb0-2ba9-43a7-84fa-11485f872136", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/fd0d9e96-ca9a-4e00-89b9-946db3a04fda", "retry_settings": { "timeout": 60, "max_retries": 2 }, "logging_level": "WARNING", - "mini_batch_size": 1 + "mini_batch_size": 1, + "partition_keys": null } }, "inputs": { @@ -915,14 +917,14 @@ "sourceJobId": null }, "systemData": { - "createdAt": "2022-10-24T04:59:54.0429964\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-10-26T06:14:52.0673601\u002B00:00", + "createdBy": "Clement Wang", "createdByType": "User" } } } ], "Variables": { - "name": "test_177211603418" + "name": "test_402372530826" } } diff --git a/sdk/ml/azure-ai-ml/tests/recordings/pipeline_job/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_job_with_parallel_job[tabular_input_e2e.yml].json b/sdk/ml/azure-ai-ml/tests/recordings/pipeline_job/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_job_with_parallel_job[tabular_input_e2e.yml].json index 79b800853387..5c2f36dfc08c 100644 --- a/sdk/ml/azure-ai-ml/tests/recordings/pipeline_job/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_job_with_parallel_job[tabular_input_e2e.yml].json +++ b/sdk/ml/azure-ai-ml/tests/recordings/pipeline_job/e2etests/test_pipeline_job.pyTestPipelineJobtest_pipeline_job_with_parallel_job[tabular_input_e2e.yml].json @@ -7,7 +7,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -15,39 +15,39 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 12:01:14 GMT", + "Date": "Wed, 26 Oct 2022 06:14:57 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-6d21a66accd834fa4cbcb3711eb2072d-5064dff1ef041e14-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-68549734f191fd55bcebdbe3fbdb6452-56d889cfc8f55a09-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-02", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "6feabad4-a7e6-43bb-847d-cd43bd1a779d", - "x-ms-ratelimit-remaining-subscription-reads": "11969", + "x-ms-correlation-request-id": "d6a0c417-f25f-4329-a111-d625615acaf0", + "x-ms-ratelimit-remaining-subscription-reads": "11985", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T120114Z:6feabad4-a7e6-43bb-847d-cd43bd1a779d", - "x-request-time": "0.225" + "x-ms-routing-request-id": "JAPANEAST:20221026T061458Z:d6a0c417-f25f-4329-a111-d625615acaf0", + "x-request-time": "0.039" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/computes/cpu-cluster", "name": "cpu-cluster", "type": "Microsoft.MachineLearningServices/workspaces/computes", - "location": "centraluseuap", + "location": "eastus2", "tags": {}, "properties": { - "createdOn": "2022-09-22T09:02:22.1899959\u002B00:00", - "modifiedOn": "2022-09-23T03:28:18.0066218\u002B00:00", + "createdOn": "2022-09-22T03:07:49.0785672\u002B00:00", + "modifiedOn": "2022-10-11T04:29:30.5828273\u002B00:00", "disableLocalAuth": false, "description": null, "resourceId": null, "computeType": "AmlCompute", - "computeLocation": "centraluseuap", + "computeLocation": "eastus2", "provisioningState": "Succeeded", "provisioningErrors": null, "isAttachedCompute": false, @@ -56,36 +56,23 @@ "vmPriority": "Dedicated", "scaleSettings": { "maxNodeCount": 4, - "minNodeCount": 1, + "minNodeCount": 0, "nodeIdleTimeBeforeScaleDown": "PT2M" }, "subnet": null, - "currentNodeCount": 3, - "targetNodeCount": 4, + "currentNodeCount": 0, + "targetNodeCount": 0, "nodeStateCounts": { - "preparingNodeCount": 1, - "runningNodeCount": 2, + "preparingNodeCount": 0, + "runningNodeCount": 0, "idleNodeCount": 0, "unusableNodeCount": 0, "leavingNodeCount": 0, "preemptedNodeCount": 0 }, - "allocationState": "Resizing", - "allocationStateTransitionTime": "2022-10-24T12:00:47.481\u002B00:00", - "errors": [ - { - "error": { - "code": "DiskFull", - "message": "ComputeNode.Id=tvmps_1a385a9430701ba60b36ba255e7e5f34cb46993f08fb4670281e9b8a60f8815b_d: There is not enough disk space on the node", - "details": [ - { - "code": "Message", - "message": "The VM disk is full. Delete jobs, tasks, or files on the node to free up space and then reboot the node." - } - ] - } - } - ], + "allocationState": "Steady", + "allocationStateTransitionTime": "2022-10-25T06:07:12.361\u002B00:00", + "errors": null, "remoteLoginPortPublicAccess": "Enabled", "osType": "Linux", "virtualMachineImage": null, @@ -102,7 +89,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -110,24 +97,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 12:01:16 GMT", + "Date": "Wed, 26 Oct 2022 06:15:00 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-48aa97b709026c4b716948e582ac0fbe-58c9dd5338887a06-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-c64063d2b23fa61e68f65ff7c25c857f-f2d40fc43e4f9c7f-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "5201e315-e67c-4dfe-a13a-2b9a21b8def7", - "x-ms-ratelimit-remaining-subscription-reads": "11968", + "x-ms-correlation-request-id": "1a0177a9-3522-4772-8888-751f431fe3bb", + "x-ms-ratelimit-remaining-subscription-reads": "11984", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T120117Z:5201e315-e67c-4dfe-a13a-2b9a21b8def7", - "x-request-time": "0.103" + "x-ms-routing-request-id": "JAPANEAST:20221026T061501Z:1a0177a9-3522-4772-8888-751f431fe3bb", + "x-request-time": "0.096" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -142,17 +129,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -166,7 +153,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -174,21 +161,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 12:01:17 GMT", + "Date": "Wed, 26 Oct 2022 06:15:00 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-a6849abb0d9b55608bf24dce7ee3a9de-de7de200d78659c4-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-e576f21afe2fade3bb1dd49693233f75-9ea0c419634a1188-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "46c4eaff-b83b-4097-91c4-f384412130c4", - "x-ms-ratelimit-remaining-subscription-writes": "1186", + "x-ms-correlation-request-id": "7c2d9b06-1bf4-4143-99f8-6f1bc5687d74", + "x-ms-ratelimit-remaining-subscription-writes": "1195", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T120117Z:46c4eaff-b83b-4097-91c4-f384412130c4", - "x-request-time": "0.106" + "x-ms-routing-request-id": "JAPANEAST:20221026T061501Z:7c2d9b06-1bf4-4143-99f8-6f1bc5687d74", + "x-request-time": "0.123" }, "ResponseBody": { "secretsType": "AccountKey", @@ -196,14 +183,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/script_parallel/digit_identification.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/script_parallel/digit_identification.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Mon, 24 Oct 2022 12:01:17 GMT", + "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.10.8 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Wed, 26 Oct 2022 06:15:01 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -213,9 +200,9 @@ "Content-Length": "1555", "Content-MD5": "4WzoZGSMp9zEx3G4j/SVnA==", "Content-Type": "application/octet-stream", - "Date": "Mon, 24 Oct 2022 12:01:17 GMT", - "ETag": "\u00220x8DA9D49D7EAA27E\u0022", - "Last-Modified": "Fri, 23 Sep 2022 09:56:10 GMT", + "Date": "Wed, 26 Oct 2022 06:15:01 GMT", + "ETag": "\u00220x8DA9D77BDF33C17\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:24:43 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -224,10 +211,10 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Fri, 23 Sep 2022 09:56:10 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:24:42 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "88bd524f-9c9e-4b52-9a39-a18be7c95512", + "x-ms-meta-name": "430c0a29-9981-4727-b4a5-8fa454b267c3", "x-ms-meta-upload_status": "completed", "x-ms-meta-version": "1", "x-ms-server-encrypted": "true", @@ -236,20 +223,20 @@ "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/script_parallel/digit_identification.py", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/script_parallel/digit_identification.py", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Mon, 24 Oct 2022 12:01:17 GMT", + "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.10.8 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Wed, 26 Oct 2022 06:15:01 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 24 Oct 2022 12:01:17 GMT", + "Date": "Wed, 26 Oct 2022 06:15:02 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -262,7 +249,7 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1?api-version=2022-05-01", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1?api-version=2022-05-01", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", @@ -270,7 +257,7 @@ "Connection": "keep-alive", "Content-Length": "304", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -280,7 +267,7 @@ }, "isAnonymous": true, "isArchived": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/script_parallel" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/script_parallel" } }, "StatusCode": 200, @@ -288,27 +275,27 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 12:01:18 GMT", + "Date": "Wed, 26 Oct 2022 06:15:02 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-b327016626e7a1071d03f13dc8d2e431-529fd42bfe56a5b1-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-819f2e0d5121179cded79798a169aa8f-f79cd451294e2e95-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "22c5dbd6-ad61-41da-b706-af8e6f6d6320", - "x-ms-ratelimit-remaining-subscription-writes": "1165", + "x-ms-correlation-request-id": "6fe4c1b6-c6a6-43ad-a53d-3abb9aa176eb", + "x-ms-ratelimit-remaining-subscription-writes": "1192", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T120118Z:22c5dbd6-ad61-41da-b706-af8e6f6d6320", - "x-request-time": "0.185" + "x-ms-routing-request-id": "JAPANEAST:20221026T061503Z:6fe4c1b6-c6a6-43ad-a53d-3abb9aa176eb", + "x-request-time": "0.251" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1", "name": "1", "type": "Microsoft.MachineLearningServices/workspaces/codes/versions", "properties": { @@ -320,14 +307,14 @@ }, "isArchived": false, "isAnonymous": false, - "codeUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/script_parallel" + "codeUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/script_parallel" }, "systemData": { - "createdAt": "2022-09-23T09:56:12.0126883\u002B00:00", - "createdBy": "Ying Chen", + "createdAt": "2022-09-23T15:24:44.8270903\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-10-24T12:01:18.3782172\u002B00:00", - "lastModifiedBy": "Xingzhi Zhang", + "lastModifiedAt": "2022-10-26T06:15:02.8993663\u002B00:00", + "lastModifiedBy": "Clement Wang", "lastModifiedByType": "User" } } @@ -341,7 +328,7 @@ "Connection": "keep-alive", "Content-Length": "416", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -353,24 +340,24 @@ }, "StatusCode": 201, "ResponseHeaders": { - "Build-ID": "caw", + "Build-ID": "chv", "Cache-Control": "no-cache", - "Content-Length": "1351", + "Content-Length": "1359", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 12:01:19 GMT", + "Date": "Wed, 26 Oct 2022 06:15:03 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-65eca52bead808e94b7a141b83a56629-fc15d581117acdd2-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-2a9f71b1dd1adb64ab0a3fe570d78110-8da3616adfe083d7-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "6b38f32d-00ec-4e96-9256-8adb78fa89ad", - "x-ms-ratelimit-remaining-subscription-writes": "1164", + "x-ms-correlation-request-id": "a20d81c6-2dff-4545-be49-d52ab6d9ce70", + "x-ms-ratelimit-remaining-subscription-writes": "1191", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T120119Z:6b38f32d-00ec-4e96-9256-8adb78fa89ad", - "x-request-time": "0.460" + "x-ms-routing-request-id": "JAPANEAST:20221026T061504Z:a20d81c6-2dff-4545-be49-d52ab6d9ce70", + "x-request-time": "0.366" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af", @@ -388,11 +375,11 @@ "osType": "Linux" }, "systemData": { - "createdAt": "2022-09-23T09:56:46.9554352\u002B00:00", - "createdBy": "Ying Chen", + "createdAt": "2022-09-23T15:25:10.3353821\u002B00:00", + "createdBy": "Zhengfei Wang", "createdByType": "User", - "lastModifiedAt": "2022-09-23T09:56:46.9554352\u002B00:00", - "lastModifiedBy": "Ying Chen", + "lastModifiedAt": "2022-09-23T15:25:10.3353821\u002B00:00", + "lastModifiedBy": "Zhengfei Wang", "lastModifiedByType": "User" } } @@ -406,7 +393,7 @@ "Connection": "keep-alive", "Content-Length": "1304", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -440,7 +427,7 @@ "logging_level": "DEBUG", "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1", "entry_script": "tabular_run_with_model.py", "append_row_to": "${{outputs.job_output_file}}", "environment": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af" @@ -460,26 +447,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "2340", + "Content-Length": "2342", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 12:01:20 GMT", + "Date": "Wed, 26 Oct 2022 06:15:04 GMT", "Expires": "-1", "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/000000000000000000000?api-version=2022-05-01", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-c96422ed7891c3b7cd5c5e3dc5dfa95a-62f74c105b14b2d3-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-5068e0f6997424ae58b1dc98ad2c32f0-a37ccdce578aa53b-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "d288a78a-fc97-4cdc-9e59-92454a05c9bf", - "x-ms-ratelimit-remaining-subscription-writes": "1163", + "x-ms-correlation-request-id": "f5df4152-a68e-48e3-a496-3c60b82ef080", + "x-ms-ratelimit-remaining-subscription-writes": "1190", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T120120Z:d288a78a-fc97-4cdc-9e59-92454a05c9bf", - "x-request-time": "0.527" + "x-ms-routing-request-id": "JAPANEAST:20221026T061505Z:f5df4152-a68e-48e3-a496-3c60b82ef080", + "x-request-time": "0.323" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/5b17fd17-2927-4d4c-8c32-3cae57ed8ed1", - "name": "5b17fd17-2927-4d4c-8c32-3cae57ed8ed1", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/c1b51460-9f13-4936-98bd-c2e990f4235a", + "name": "c1b51460-9f13-4936-98bd-c2e990f4235a", "type": "Microsoft.MachineLearningServices/workspaces/components/versions", "properties": { "description": null, @@ -489,7 +476,7 @@ "isAnonymous": true, "componentSpec": { "name": "azureml_anonymous", - "version": "5b17fd17-2927-4d4c-8c32-3cae57ed8ed1", + "version": "c1b51460-9f13-4936-98bd-c2e990f4235a", "display_name": "hello_world_inline_parallel_tabular_job_1", "is_deterministic": "True", "type": "parallel", @@ -509,7 +496,7 @@ } }, "task": { - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1", "environment": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af", "entry_script": "tabular_run_with_model.py", "type": "run_function", @@ -529,11 +516,11 @@ } }, "systemData": { - "createdAt": "2022-09-23T09:57:32.1111058\u002B00:00", - "createdBy": "Ying Chen", + "createdAt": "2022-10-25T05:55:15.1368399\u002B00:00", + "createdBy": "Xiaole Wen", "createdByType": "User", - "lastModifiedAt": "2022-09-23T09:57:32.6001954\u002B00:00", - "lastModifiedBy": "Ying Chen", + "lastModifiedAt": "2022-10-25T05:55:15.3198285\u002B00:00", + "lastModifiedBy": "Xiaole Wen", "lastModifiedByType": "User" } } @@ -545,7 +532,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -553,24 +540,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 12:01:20 GMT", + "Date": "Wed, 26 Oct 2022 06:15:05 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-7b5bb677c22e6a738ce307ffc159c6ca-6a7339a9f4a9524d-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-b81b6e64865c2d2652fbe1e2f26f91b8-238a5c8ca52d4d79-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "d279bb75-c1ce-4cf2-ac5e-c79dc8c5358c", - "x-ms-ratelimit-remaining-subscription-reads": "11967", + "x-ms-correlation-request-id": "3ef2e2c6-bf62-4ebd-8e8f-178e3f2cac39", + "x-ms-ratelimit-remaining-subscription-reads": "11983", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T120121Z:d279bb75-c1ce-4cf2-ac5e-c79dc8c5358c", - "x-request-time": "0.214" + "x-ms-routing-request-id": "JAPANEAST:20221026T061506Z:3ef2e2c6-bf62-4ebd-8e8f-178e3f2cac39", + "x-request-time": "0.230" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -585,17 +572,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -609,7 +596,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -617,21 +604,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 12:01:21 GMT", + "Date": "Wed, 26 Oct 2022 06:15:05 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-503ff33cf1ae1e099c5f41be1f095658-67b70897f6f2fd84-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-4fa2e17eb7ae0b9b1ec2f7034a7cfc17-82559d00f998853a-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "63967212-617d-4856-a615-48e94e84e107", - "x-ms-ratelimit-remaining-subscription-writes": "1185", + "x-ms-correlation-request-id": "053a2be6-b1ce-4c17-b62c-9ae1b23b51f8", + "x-ms-ratelimit-remaining-subscription-writes": "1194", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T120121Z:63967212-617d-4856-a615-48e94e84e107", - "x-request-time": "0.088" + "x-ms-routing-request-id": "JAPANEAST:20221026T061506Z:053a2be6-b1ce-4c17-b62c-9ae1b23b51f8", + "x-request-time": "0.107" }, "ResponseBody": { "secretsType": "AccountKey", @@ -639,14 +626,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/neural-iris-mltable/MLTable", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/neural-iris-mltable/MLTable", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Mon, 24 Oct 2022 12:01:21 GMT", + "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.10.8 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Wed, 26 Oct 2022 06:15:06 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -656,9 +643,9 @@ "Content-Length": "152", "Content-MD5": "LPwZTVvE9cmq2xCV9B8RmQ==", "Content-Type": "application/octet-stream", - "Date": "Mon, 24 Oct 2022 12:01:21 GMT", - "ETag": "\u00220x8DA9D4A0B341E03\u0022", - "Last-Modified": "Fri, 23 Sep 2022 09:57:36 GMT", + "Date": "Wed, 26 Oct 2022 06:15:06 GMT", + "ETag": "\u00220x8DA9D77E4BE9973\u0022", + "Last-Modified": "Fri, 23 Sep 2022 15:25:49 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -667,32 +654,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Fri, 23 Sep 2022 09:57:36 GMT", + "x-ms-creation-time": "Fri, 23 Sep 2022 15:25:48 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "b4ef3474-9bb7-4991-ba76-2c6587bb4557", + "x-ms-meta-name": "75be94a1-b11f-438f-9809-e66170c6a572", "x-ms-meta-upload_status": "completed", - "x-ms-meta-version": "8589c596-dddd-4f5d-89f8-dead725c2efc", + "x-ms-meta-version": "b56612a1-59bf-45b4-bfb9-4924980b2134", "x-ms-server-encrypted": "true", "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/neural-iris-mltable/MLTable", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/neural-iris-mltable/MLTable", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Mon, 24 Oct 2022 12:01:21 GMT", + "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.10.8 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Wed, 26 Oct 2022 06:15:07 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 24 Oct 2022 12:01:21 GMT", + "Date": "Wed, 26 Oct 2022 06:15:07 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -711,7 +698,7 @@ "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -719,24 +706,24 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 12:01:22 GMT", + "Date": "Wed, 26 Oct 2022 06:15:07 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-c587121fad858d5a45bc61b40a5085f2-f0aa9c40a7ab1309-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-3c1e5beb69579241acf9e29147f0b183-0504da5de0584d8c-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": [ "Accept-Encoding", "Accept-Encoding" ], - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "85bf7d8c-16a1-4718-b510-6cf0320778f3", - "x-ms-ratelimit-remaining-subscription-reads": "11966", + "x-ms-correlation-request-id": "a84e29aa-daf1-4a87-8110-edc45c02e756", + "x-ms-ratelimit-remaining-subscription-reads": "11982", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T120122Z:85bf7d8c-16a1-4718-b510-6cf0320778f3", - "x-request-time": "0.103" + "x-ms-routing-request-id": "JAPANEAST:20221026T061507Z:a84e29aa-daf1-4a87-8110-edc45c02e756", + "x-request-time": "0.116" }, "ResponseBody": { "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/datastores/workspaceblobstore", @@ -751,17 +738,17 @@ "credentialsType": "AccountKey" }, "datastoreType": "AzureBlob", - "accountName": "sagvgsoim6nmhbq", - "containerName": "azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8", + "accountName": "sav6dhrxexwlv7g", + "containerName": "azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c", "endpoint": "core.windows.net", "protocol": "https", "serviceDataAccessAuthIdentity": "WorkspaceSystemAssignedIdentity" }, "systemData": { - "createdAt": "2022-09-22T09:02:03.2629568\u002B00:00", + "createdAt": "2022-09-22T03:07:29.4396872\u002B00:00", "createdBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "createdByType": "Application", - "lastModifiedAt": "2022-09-22T09:02:04.166989\u002B00:00", + "lastModifiedAt": "2022-09-22T03:07:30.424941\u002B00:00", "lastModifiedBy": "779301c0-18b2-4cdc-801b-a0a3368fee0a", "lastModifiedByType": "Application" } @@ -775,7 +762,7 @@ "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", "Content-Length": "0", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": null, "StatusCode": 200, @@ -783,21 +770,21 @@ "Cache-Control": "no-cache", "Content-Encoding": "gzip", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 12:01:22 GMT", + "Date": "Wed, 26 Oct 2022 06:15:07 GMT", "Expires": "-1", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-238352f258a59c18350af85f0930ba79-36fcb4c70c2cc1eb-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-5bbcd04946ebd9e40154dd622c2f1c56-f31804887a4d3a1d-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", "Transfer-Encoding": "chunked", "Vary": "Accept-Encoding", - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "64ee448f-9ee5-4a86-ba20-5a00ad82e45b", - "x-ms-ratelimit-remaining-subscription-writes": "1184", + "x-ms-correlation-request-id": "515f65f0-8709-4739-b393-90ecd94cfb0b", + "x-ms-ratelimit-remaining-subscription-writes": "1193", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T120123Z:64ee448f-9ee5-4a86-ba20-5a00ad82e45b", - "x-request-time": "0.088" + "x-ms-routing-request-id": "JAPANEAST:20221026T061508Z:515f65f0-8709-4739-b393-90ecd94cfb0b", + "x-request-time": "0.147" }, "ResponseBody": { "secretsType": "AccountKey", @@ -805,14 +792,14 @@ } }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/LocalUpload/00000000000000000000000000000000/model/iris_model/MLmodel", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/LocalUpload/00000000000000000000000000000000/model/iris_model/MLmodel", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Mon, 24 Oct 2022 12:01:23 GMT", + "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.10.8 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Wed, 26 Oct 2022 06:15:08 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, @@ -822,9 +809,9 @@ "Content-Length": "298", "Content-MD5": "HaKpUL6X1WimkPVJF2lHiQ==", "Content-Type": "application/octet-stream", - "Date": "Mon, 24 Oct 2022 12:01:22 GMT", - "ETag": "\u00220x8DAB57CA23BE6F9\u0022", - "Last-Modified": "Mon, 24 Oct 2022 05:00:12 GMT", + "Date": "Wed, 26 Oct 2022 06:15:08 GMT", + "ETag": "\u00220x8DAB5ADA06F1E17\u0022", + "Last-Modified": "Mon, 24 Oct 2022 10:50:55 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -833,32 +820,32 @@ "x-ms-access-tier": "Hot", "x-ms-access-tier-inferred": "true", "x-ms-blob-type": "BlockBlob", - "x-ms-creation-time": "Mon, 24 Oct 2022 05:00:11 GMT", + "x-ms-creation-time": "Mon, 24 Oct 2022 10:50:53 GMT", "x-ms-lease-state": "available", "x-ms-lease-status": "unlocked", - "x-ms-meta-name": "862e882a-f22f-4056-9ca5-b27d9f49a0fc", + "x-ms-meta-name": "9c212b41-a364-4c59-8722-2af33bd301d3", "x-ms-meta-upload_status": "completed", - "x-ms-meta-version": "508dd8b0-9462-41ba-a60f-574833ab15ab", + "x-ms-meta-version": "8eda34db-fb76-4dae-a634-f083a7f5f965", "x-ms-server-encrypted": "true", "x-ms-version": "2021-08-06" }, "ResponseBody": null }, { - "RequestUri": "https://sagvgsoim6nmhbq.blob.core.windows.net/azureml-blobstore-e61cd5e2-512f-475e-9842-5e2a973993b8/az-ml-artifacts/00000000000000000000000000000000/model/iris_model/MLmodel", + "RequestUri": "https://sav6dhrxexwlv7g.blob.core.windows.net/azureml-blobstore-e950f876-7257-4cf3-99a5-ff66812ac44c/az-ml-artifacts/00000000000000000000000000000000/model/iris_model/MLmodel", "RequestMethod": "HEAD", "RequestHeaders": { "Accept": "application/xml", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "User-Agent": "azsdk-python-storage-blob/12.14.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)", - "x-ms-date": "Mon, 24 Oct 2022 12:01:23 GMT", + "User-Agent": "azsdk-python-storage-blob/12.13.1 Python/3.10.8 (Windows-10-10.0.22621-SP0)", + "x-ms-date": "Wed, 26 Oct 2022 06:15:08 GMT", "x-ms-version": "2021-08-06" }, "RequestBody": null, "StatusCode": 404, "ResponseHeaders": { - "Date": "Mon, 24 Oct 2022 12:01:23 GMT", + "Date": "Wed, 26 Oct 2022 06:15:08 GMT", "Server": [ "Windows-Azure-Blob/1.0", "Microsoft-HTTPAPI/2.0" @@ -871,15 +858,15 @@ "ResponseBody": null }, { - "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_812467624275?api-version=2022-10-01-preview", + "RequestUri": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_580492643284?api-version=2022-10-01-preview", "RequestMethod": "PUT", "RequestHeaders": { "Accept": "application/json", "Accept-Encoding": "gzip, deflate", "Connection": "keep-alive", - "Content-Length": "2512", + "Content-Length": "2536", "Content-Type": "application/json", - "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.9.10 (Windows-10-10.0.22621-SP0)" + "User-Agent": "azure-ai-ml/1.1.0 azsdk-python-mgmt-machinelearningservices/0.1.0 Python/3.10.8 (Windows-10-10.0.22621-SP0)" }, "RequestBody": { "properties": { @@ -889,7 +876,7 @@ "tag": "tagvalue", "owner": "sdkteam" }, - "displayName": "test_812467624275", + "displayName": "test_580492643284", "experimentName": "azure-ai-ml", "isArchived": false, "jobType": "Pipeline", @@ -915,7 +902,7 @@ "max_concurrency_per_instance": 2, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1", "entry_script": "tabular_run_with_model.py", "append_row_to": "${{outputs.job_output_file}}", "environment": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af" @@ -943,13 +930,14 @@ }, "properties": {}, "_source": "YAML.JOB", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/5b17fd17-2927-4d4c-8c32-3cae57ed8ed1", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/c1b51460-9f13-4936-98bd-c2e990f4235a", "retry_settings": { "timeout": 60, "max_retries": 2 }, "logging_level": "DEBUG", - "mini_batch_size": 102400 + "mini_batch_size": 102400, + "partition_keys": null } }, "outputs": { @@ -966,26 +954,26 @@ "StatusCode": 201, "ResponseHeaders": { "Cache-Control": "no-cache", - "Content-Length": "4928", + "Content-Length": "4957", "Content-Type": "application/json; charset=utf-8", - "Date": "Mon, 24 Oct 2022 12:01:31 GMT", + "Date": "Wed, 26 Oct 2022 06:15:16 GMT", "Expires": "-1", - "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_812467624275?api-version=2022-10-01-preview", + "Location": "https://management.azure.com/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_580492643284?api-version=2022-10-01-preview", "Pragma": "no-cache", - "Request-Context": "appId=cid-v1:512cc15a-13b5-415b-bfd0-dce7accb6bb1", - "Server-Timing": "traceparent;desc=\u002200-538033200cd876ee4feccc6b40717037-acd078944b11e9a3-00\u0022", + "Request-Context": "appId=cid-v1:2d2e8e63-272e-4b3c-8598-4ee570a0e70d", + "Server-Timing": "traceparent;desc=\u002200-c240b8ab47d40974f665cb6ac214f24f-7e195fae53223d0d-01\u0022", "Strict-Transport-Security": "max-age=31536000; includeSubDomains", - "x-aml-cluster": "vienna-test-westus2-01", + "x-aml-cluster": "vienna-eastus2-01", "X-Content-Type-Options": "nosniff", - "x-ms-correlation-request-id": "e26d0ddc-56d6-4c8b-a6b2-d75f338ff8d5", - "x-ms-ratelimit-remaining-subscription-writes": "1162", + "x-ms-correlation-request-id": "c599385f-92f0-41ee-a8f4-4ca8ced1da17", + "x-ms-ratelimit-remaining-subscription-writes": "1189", "x-ms-response-type": "standard", - "x-ms-routing-request-id": "JAPANEAST:20221024T120131Z:e26d0ddc-56d6-4c8b-a6b2-d75f338ff8d5", - "x-request-time": "3.859" + "x-ms-routing-request-id": "JAPANEAST:20221026T061517Z:c599385f-92f0-41ee-a8f4-4ca8ced1da17", + "x-request-time": "4.087" }, "ResponseBody": { - "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_812467624275", - "name": "test_812467624275", + "id": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/jobs/test_580492643284", + "name": "test_580492643284", "type": "Microsoft.MachineLearningServices/workspaces/jobs", "properties": { "description": "The hello world pipeline job with inline parallel job", @@ -1004,14 +992,14 @@ "azureml.defaultDataStoreName": "workspaceblobstore", "azureml.pipelineComponent": "pipelinerun" }, - "displayName": "test_812467624275", - "status": "Running", + "displayName": "test_580492643284", + "status": "Preparing", "experimentName": "azure-ai-ml", "services": { "Tracking": { "jobServiceType": "Tracking", "port": null, - "endpoint": "azureml://master.api.azureml-test.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", + "endpoint": "azureml://eastus2.api.azureml.ms/mlflow/v1.0/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000?", "status": null, "errorMessage": null, "properties": null, @@ -1020,7 +1008,7 @@ "Studio": { "jobServiceType": "Studio", "port": null, - "endpoint": "https://ml.azure.com/runs/test_812467624275?wsid=/subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000", + "endpoint": "https://ml.azure.com/runs/test_580492643284?wsid=/subscriptions/00000000-0000-0000-0000-000000000/resourcegroups/00000/workspaces/00000", "status": null, "errorMessage": null, "properties": null, @@ -1045,7 +1033,7 @@ "max_concurrency_per_instance": 2, "task": { "type": "run_function", - "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/88bd524f-9c9e-4b52-9a39-a18be7c95512/versions/1", + "code": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/codes/430c0a29-9981-4727-b4a5-8fa454b267c3/versions/1", "entry_script": "tabular_run_with_model.py", "append_row_to": "${{outputs.job_output_file}}", "environment": "azureml:/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/environments/CliV2AnonymousEnvironment/versions/6fe7be4cbb153a3107ff961211b4a9af" @@ -1073,13 +1061,14 @@ }, "properties": {}, "_source": "YAML.JOB", - "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/5b17fd17-2927-4d4c-8c32-3cae57ed8ed1", + "componentId": "/subscriptions/00000000-0000-0000-0000-000000000/resourceGroups/00000/providers/Microsoft.MachineLearningServices/workspaces/00000/components/azureml_anonymous/versions/c1b51460-9f13-4936-98bd-c2e990f4235a", "retry_settings": { "timeout": 60, "max_retries": 2 }, "logging_level": "DEBUG", - "mini_batch_size": 102400 + "mini_batch_size": 102400, + "partition_keys": null } }, "inputs": { @@ -1107,14 +1096,14 @@ "sourceJobId": null }, "systemData": { - "createdAt": "2022-10-24T12:01:29.9177806\u002B00:00", - "createdBy": "Xingzhi Zhang", + "createdAt": "2022-10-26T06:15:16.9324831\u002B00:00", + "createdBy": "Clement Wang", "createdByType": "User" } } } ], "Variables": { - "name": "test_812467624275" + "name": "test_580492643284" } } diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/components/parallel_component_with_partition_keys.yml b/sdk/ml/azure-ai-ml/tests/test_configs/components/parallel_component_with_partition_keys.yml new file mode 100644 index 000000000000..a6cd2210de81 --- /dev/null +++ b/sdk/ml/azure-ai-ml/tests/test_configs/components/parallel_component_with_partition_keys.yml @@ -0,0 +1,55 @@ +#source ../configs/parallel-job/batch-score-ParallelComponent.yaml +$schema: http://azureml/sdk-2-0/ParallelComponent.json +name: batch_score +type: parallel +version: 1.0.0 +display_name: BatchScore +description: parallel component for batch score + +inputs: + score_input: + type: mltable + description: The data to be split and scored in parallel. + optional: false + label: + type: uri_file + description: Other reference data for batch scoring, e.g. labels. + optional: false + score_model: + type: custom_model + description: The model for batch score. + optional: false + +outputs: + scored_result: + type: mltable + scoring_summary: + type: uri_file + +resources: + instance_count: 2 + +retry_settings: + max_retries: 10 + timeout: 3 + +max_concurrency_per_instance: 12 +error_threshold: 10 +mini_batch_error_threshold: 5 +logging_level: "INFO" + +partition_keys: +- "foo" +- "bar" +input_data: ${{inputs.score_input}} + +task: + type: run_function + code: "../python" + entry_script: pass_through.py + program_arguments: >- # optional + --label ${{inputs.label}} + --model ${{inputs.score_model}} + --output_scored_result ${{outputs.scored_result}} + append_row_to: ${{outputs.scoring_summary}} # optional, If Null, equals to summary_only mode in v1. + environment: azureml:AzureML-Minimal:2 diff --git a/sdk/ml/azure-ai-ml/tests/test_configs/components/parallel_component_with_partition_keys_rest.json b/sdk/ml/azure-ai-ml/tests/test_configs/components/parallel_component_with_partition_keys_rest.json new file mode 100644 index 000000000000..a4f1ca882e96 --- /dev/null +++ b/sdk/ml/azure-ai-ml/tests/test_configs/components/parallel_component_with_partition_keys_rest.json @@ -0,0 +1,73 @@ +{ + "id": "/subscriptions/4faaaf21-663f-4391-96fd-47197c630979/resourceGroups/DesignerTestRG/providers/Microsoft.MachineLearningServices/workspaces/DesignerTest-centraluseuap/components/test_389889218331/versions/0.0.1", + "name": null, + "type": null, + "properties": { + "description": null, + "tags": null, + "properties": {}, + "isAnonymous": false, + "componentSpec": { + "$schema": "http://azureml/sdk-2-0/ParallelComponent.json", + "name": "batch_score", + "_source": "CLASS", + "version": "1.0.0", + "type": "parallel", + "display_name": "BatchScore", + "description": "parallel component for batch score", + "inputs": { + "score_input": { + "name": "score_input", + "optional": "False", + "description": "The data to be split and scored in parallel.", + "type": "mltable" + }, + "label": { + "type": "uri_file", + "description": "Other reference data for batch scoring, e.g. labels.", + "optional": false + }, + "score_model": { + "type": "custom_model", + "description": "The model for batch score.", + "optional": false + } + }, + "outputs": { + "scored_result": { + "type": "mltable" + }, + "scoring_summary": { + "type": "uri_file" + } + }, + "resources": { + "instance_count": 2 + }, + "retry_settings": { + "max_retries": 10, + "timeout": 3 + }, + "max_concurrency_per_instance": 12, + "mini_batch_error_threshold": 5, + "error_threshold": 10, + "logging_level": "INFO", + "partition_keys": "[\"foo\", \"bar\"]", + "input_data": "${{inputs.score_input}}", + "task": { + "type": "run_function", + "code": "azureml:/subscriptions/xxx/resourceGroups/xxx/providers/Microsoft.MachineLearningServices/workspaces/xxx/codes/xxx/versions/1", + "entry_script": "pass_through.py", + "program_arguments": "--label ${{inputs.label}} --model ${{inputs.score_model}} --output_scored_result ${{outputs.scored_result}}", + "append_row_to": "${{outputs.scoring_summary}}", + "environment": "azureml:AzureML-Minimal:2" + } + } + }, + "systemData": { + "createdAt": "2022-03-11T02:58:14.9644668Z", + "createdBy": "Xiaoran Li", + "createdByType": "User", + "lastModifiedAt": "2022-03-11T02:58:15.7637279Z" + } +}